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

[airflow] tag nightly-master updated (d627dfa -> b66b54c)

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

github-bot pushed a change to tag nightly-master
in repository https://gitbox.apache.org/repos/asf/airflow.git.


*** WARNING: tag nightly-master was modified! ***

    from d627dfa  (commit)
      to b66b54c  (commit)
    from 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 ea7e64f  Relax required version for `python-telegram-bot` (#15776)
     add d78f8c5  Remove unused constant in serialization code (#15824)
     add 8ab9c0c  Ensure that task preceeding a PythonVirtualenvOperator doesn't fail (#15822)
     add 717dcfd  Improve feedback message after installing or upgrading airflow with helm chart (#15820)
     add 1316f69  Add download links to provider documentation (#15739)
     add 8799b9f  Migrate dag js (#15823)
     add 2a8bae9  Build chart parameter docs from `values.schema.json` (#15827)
     add c493b4d  Rename docs fields in chart values schema (#15828)
     add 37d549b  Save pod name to xcom for KubernetesPodOperator (#15755)
     add 51e54cb  Improve test coverage of task_command.py FIXES: #15524 (#15760)
     add 634c12d  Keep confirmDeleteDag inline html (#15836)
     add 1467046  CloudwatchTaskHandler reads timestamp from Cloudwatch events (#15173)
     add bcfa0cb  Make DAG dependency detector configurable (#15829)
     add e84fb58  Fixes building pre-2.1 Airflow images from 2.1 Dockerfiles. (#15802)
     add 758ad90  Move `airflowLocalSettings` to be a top level chart param (#15838)
     add 7eeb362  Explicitly point Jinja2 documentation to 2.11.x (#15847)
     add 1646dff  Support extra env vars on gitsync containers (#15842)
     add 3f0a904  Add back-compat shim for BranchDateTimeOperator rename (#15849)
     add 6f5f4dc  Revert "Add back-compat shim for BranchDateTimeOperator rename (#15849)" (#15853)
     add b8868fa  Fix modal import in graph.js (#15852)
     add 6d9fc3e  Fix docstring formatting on ``SlackHook`` (#15840)
     add 0893166  Set `airflowPodAnnotations` on Flower and `KuberneteExecutor` workers (#15859)
     add 8ecc835  Remove unused licenses: `python-nvd3` & `python-slugify` (#15860)
     add 3152f21  Check chart labels on all objects (#15686)
     add 71425cd  Remove unused licenses from LICENSE (#15863)
     add b77fff7  Make Helm Chart ready for release (#15864)
     add 6f646fd  Add support for listing user objects. (#15862)
     add 2180608  Default `resultBackendConnection` to `metadataConnection` (#15861)
     add ec39857  Add more metadata to `Chart.yaml` (#15866)
     add b08f95a  Update Instructions to Install Chart from source (#15868)
     add 12b2cac  Fix static check (#15869)
     add 38ecbd6  Move common pitfall documentation to Airflow docs (#15183)
     add 41d7de3  Fix pause/unpause Dag on dag view (#15865)
     add 512f396  Dev: Update command to install ``setuptools-build-subpackage`` (#15872)
     add 96e2915  Fix missing mkdir for hadoop dockerfile (#15871)
     add 83b50d3  New production guide for helm chart docs (#15867)
     add dcb8932  Update KylinHook docstring (#15602)
     add 6b46af1  Relax the version constraint of rich (#15531)
     add 3919ee6  Fix `task_instance_mutation_hook` when importing airflow.models.dagrun (#15851)
     add b90bb6e  Docs: Fix examples values in docs (#15878)
     add 13bb50c  Revert "Docs: Fix examples values in docs (#15878)" (#15880)
     add 3e38814  Better multiline string formatting for chart docs (#15881)
     add d3f7c53  Add v2.1 changelog  (#15811)
     add ed35818  Fix docs spelling errors (#15884)
     add 31894fa  Update installation page (#15737)
     add bb115da  Get rid of requests as core dependency (#15781)
     add c7da390  Detect 🚧 as a WIP PR (#15893)
     add 821ea6f  Fix spacing in ``AwsBatchWaitersHook`` docstring (#15839)
     add ac3454e  Fix 500 error from updateTaskInstancesState API endpoint when `dry_run` not passed (#15889)
     add 12995cf  Replace DockerOperator's 'volumes' arg for 'mounts' (#15843)
     add 57f6635  Use 'authentication backend' instead of executor in the section about authentication backends. (#15894)
     add abcd487  Add optional result handler to database hooks (#15581)
     add fe0600c  Faster helm unit tests (#15874)
     add b2de542  Enforce formatting on helm chart json schema files (#15895)
     add 162e320  Add Asana Provider (#14521)
     add b7d1ea9  Add Airflow Standalone command (#15826)
     add 6309fb7  Add missing word to release docs. (#15898)
     add a73ba4b  fix modal actions (#15896)
     add d88d117  Fix task search function in Graph view (#15901)
     add 811f05f  Also check chart schema when the schema itself changes (#15902)
     add 2a7298d  Use different executors for Helm Chart tests in CI (#15791)
     add 7ea1b84  Ensure that secrets are masked no matter what logging config is in use (#15899)
     add 70cf5c2  Set unique name on ``pre-commit`` hook and update schema (#15903)
     add 2cbaff0  Update example `KubernetesExecutor` `git-sync` pod template file (#15904)
     add c844ff7  Fix colon spacing in ``AzureDataExplorerHook`` docstring (#15841)
     add 180df03  Add missing License details for ``Connexion`` (#15906)
     add 5724fd8  Remove Version suffix for SVN while releasing (#15905)
     add 208b0c7  Add proper rat-excludes and missing licence (#15908)
     add 0c2848c  Prep for 2.1.0 release (#15913)
     add 2b8dc22  Add support cli delete user by email (#15873)
     add 1f5d7f4  Update version to next dev version (#15916)
     add 4295845  Sandbox templates (#15912)
     add 6f8c204  fix dag dependency search (#15924)
     add 20f3639  Add `template_fields` to `S3ToSnowflake` operator (#15926)
     add 76a80bb  Move plyvel to google provider extra (#15812)
     add 6f1c6fe  Remove the `set -x` in mypy check producing verbose output (#15932)
     add 89bef91  Add usage for --package-filter option (#15918)
     add e1cdad0  Improve Helm Chart Git-Sync documentation (#15937)
     add b709619  Updates branches and branch documentation after 2.1.0rc1 (#15528)
     add cd27124  Correctly implement autocomplete early return (#15940)
     add 89b7b71  Fix broken link (#15911)
     add 858f93c  add version life cycle table (#15936)
     add 6fd6712  Chart: Add warning about missing ``knownHosts`` (#15950)
     add e01b4e6  Mount DAGs read only when using ``gitsync`` (#15953)
     add 2be7f90  Update Helm Chart docs for 1.0.0 release (#15957)
     add 5bd6ea7  Add Badge for Artifact Hub (#15958)
     add 7106269  Fix typo in production guide for HelmChart (#15966)
     add deececc  Fail tasks in scheduler when executor reports they failed (#15929)
     add ce778d3  Add memory usage warning in quick-start documentation (#15967)
     add a51a100  Produce less output from breeze when VERBOSE_COMMANDS is set (#15970)
     add 733bec9  Bug Fix Pod-Template Affinity Ignored due to empty Affinity K8S Object (#15787)
     add 18b2c6d  Removes unnecessary function call (#15956)
     add fabe8a2  Chart: Remove ``git-sync``: ``root`` and ``dest`` params (#15955)
     add 85b2ccb  Add `KubernetesPodOperat` `pod-template-file` jinja template support (#15942)
     add aa4713e  Use api version only in GoogleAdsHook not operators (#15266)
     add bb43e06  Add more tests for the kubernetes executor (#15992)
     add 9875f64  `loadBalancerIP` and `annotations` for both Flower and Webserver (#15972)
     add 8084cfb  Chart: ``gitsync`` Clean Up for ``KubernetesExecutor``  (#15925)
     add ee470e1  Fix failing spelling check on Master (#15998)
     add 476d0f6  Bump pyupgrade v2.13.0 to v2.18.1 (#15991)
     add 8f9538e  Add Docs for ``default_pool`` slots (#15997)
     add b66b54c  Add proper link for wheel packages in docs. (#15999)

No new revisions were added by this update.

Summary of changes:
 .editorconfig                                      |    3 +
 .github/mergeable.yml                              |    2 +-
 .github/workflows/build-images-workflow-run.yml    |    3 +-
 .github/workflows/ci.yml                           |   28 +-
 .gitignore                                         |    1 +
 .pre-commit-config.yaml                            |   93 +-
 .rat-excludes                                      |    9 +
 BREEZE.rst                                         |   27 +-
 CHANGELOG.txt                                      |  208 ++
 CI.rst                                             |   17 +-
 CONTRIBUTING.rst                                   |   42 +-
 Dockerfile                                         |   38 +-
 Dockerfile.ci                                      |   31 +-
 IMAGES.rst                                         |   28 +-
 INSTALL                                            |   20 +-
 LICENSE                                            |    4 +-
 NOTICE                                             |   10 -
 README.md                                          |   19 +
 STATIC_CODE_CHECKS.rst                             |    2 +
 TESTING.rst                                        |   25 +-
 UPDATING.md                                        |   27 +-
 .../.gitignore => airflow/_vendor/__init__.py      |    0
 airflow/_vendor/connexion/__init__.py              |   48 +
 airflow/_vendor/connexion/__main__.py              |    3 +
 airflow/_vendor/connexion/apis/__init__.py         |    1 +
 airflow/_vendor/connexion/apis/abstract.py         |  446 ++++
 airflow/_vendor/connexion/apis/aiohttp_api.py      |  394 +++
 airflow/_vendor/connexion/apis/flask_api.py        |  310 +++
 airflow/_vendor/connexion/apis/flask_utils.py      |   81 +
 airflow/_vendor/connexion/apps/__init__.py         |    1 +
 airflow/_vendor/connexion/apps/abstract.py         |  249 ++
 airflow/_vendor/connexion/apps/aiohttp_app.py      |   95 +
 airflow/_vendor/connexion/apps/flask_app.py        |  138 +
 airflow/_vendor/connexion/cli.py                   |  210 ++
 .../_vendor/connexion/decorators/__init__.py       |    0
 .../connexion/decorators/coroutine_wrappers.py     |   53 +
 airflow/_vendor/connexion/decorators/decorator.py  |   51 +
 airflow/_vendor/connexion/decorators/metrics.py    |   54 +
 airflow/_vendor/connexion/decorators/parameter.py  |  123 +
 airflow/_vendor/connexion/decorators/produces.py   |   49 +
 airflow/_vendor/connexion/decorators/response.py   |  112 +
 airflow/_vendor/connexion/decorators/security.py   |  341 +++
 .../_vendor/connexion/decorators/uri_parsing.py    |  329 +++
 airflow/_vendor/connexion/decorators/validation.py |  386 +++
 airflow/_vendor/connexion/exceptions.py            |  142 ++
 airflow/_vendor/connexion/handlers.py              |   85 +
 airflow/_vendor/connexion/http_facts.py            |   15 +
 airflow/_vendor/connexion/json_schema.py           |  114 +
 airflow/_vendor/connexion/jsonifier.py             |   57 +
 airflow/_vendor/connexion/lifecycle.py             |   41 +
 airflow/_vendor/connexion/mock.py                  |   47 +
 airflow/_vendor/connexion/operations/__init__.py   |    8 +
 airflow/_vendor/connexion/operations/abstract.py   |  445 ++++
 airflow/_vendor/connexion/operations/compat.py     |    3 +
 airflow/_vendor/connexion/operations/openapi.py    |  380 +++
 airflow/_vendor/connexion/operations/secure.py     |  164 ++
 airflow/_vendor/connexion/operations/swagger2.py   |  310 +++
 airflow/_vendor/connexion/options.py               |  144 ++
 airflow/_vendor/connexion/problem.py               |   42 +
 airflow/_vendor/connexion/resolver.py              |  192 ++
 airflow/_vendor/connexion/setup.cfg                |    7 +
 airflow/_vendor/connexion/setup.py                 |  119 +
 airflow/_vendor/connexion/spec.py                  |  262 ++
 airflow/_vendor/connexion/utils.py                 |  250 ++
 airflow/api/auth/backend/basic_auth.py             |    5 +-
 airflow/api/auth/backend/default.py                |    6 +-
 airflow/api/auth/backend/deny_all.py               |    5 +-
 airflow/api/auth/backend/kerberos_auth.py          |    5 +-
 airflow/api/client/api_client.py                   |    4 +-
 airflow/api/common/experimental/mark_tasks.py      |    2 +-
 .../api_connexion/endpoints/connection_endpoint.py |    2 +-
 .../api_connexion/endpoints/dag_run_endpoint.py    |    2 +-
 .../endpoints/role_and_permission_endpoint.py      |    2 +-
 airflow/api_connexion/exceptions.py                |    2 +-
 airflow/api_connexion/openapi/v1.yaml              |    2 +-
 .../api_connexion/schemas/task_instance_schema.py  |    2 +-
 airflow/cli/cli_parser.py                          |    8 +-
 airflow/cli/commands/info_command.py               |    6 +-
 airflow/cli/commands/role_command.py               |    2 +-
 airflow/cli/commands/standalone_command.py         |  275 ++
 airflow/cli/commands/task_command.py               |    2 +-
 airflow/cli/commands/user_command.py               |   31 +-
 airflow/config_templates/config.yml                |   31 +-
 airflow/config_templates/default_airflow.cfg       |   24 +-
 airflow/configuration.py                           |    3 +-
 airflow/decorators/base.py                         |    8 +-
 airflow/decorators/task_group.py                   |    7 +-
 airflow/example_dags/example_dag_decorator.py      |    5 +-
 airflow/example_dags/tutorial.py                   |    9 +-
 airflow/executors/base_executor.py                 |    2 +-
 airflow/executors/celery_executor.py               |    2 +-
 airflow/executors/debug_executor.py                |    2 +-
 airflow/hooks/dbapi.py                             |   41 +-
 airflow/jobs/backfill_job.py                       |    2 +-
 airflow/jobs/local_task_job.py                     |    2 +-
 airflow/jobs/scheduler_job.py                      |   12 +-
 airflow/kubernetes/pod_generator.py                |    2 +-
 .../git_sync_template.yaml                         |   28 +-
 airflow/logging_config.py                          |   13 +-
 airflow/models/baseoperator.py                     |    7 +-
 airflow/models/dag.py                              |   24 +-
 airflow/models/dagbag.py                           |   10 +-
 airflow/models/dagrun.py                           |    3 +-
 airflow/models/taskinstance.py                     |   15 +-
 airflow/operators/bash.py                          |    2 +-
 airflow/operators/python.py                        |    5 +
 airflow/operators/sql.py                           |    2 +-
 airflow/providers/airbyte/hooks/airbyte.py         |    2 +-
 .../providers/amazon/aws/hooks/batch_waiters.py    |    4 +-
 airflow/providers/amazon/aws/hooks/glue.py         |    2 +-
 .../amazon/aws/log/cloudwatch_task_handler.py      |   11 +-
 .../providers/amazon/aws/transfers/mongo_to_s3.py  |    7 +-
 .../apache/druid/transfers/hive_to_druid.py        |    2 +-
 airflow/providers/apache/hive/hooks/hive.py        |    8 +-
 .../providers/apache/hive/operators/hive_stats.py  |    2 +-
 airflow/providers/apache/kylin/hooks/kylin.py      |    2 +
 .../providers/asana/CHANGELOG.rst                  |   40 +-
 airflow/providers/{neo4j => asana}/README.md       |    0
 .../providers/asana}/__init__.py                   |    0
 .../providers/asana/example_dags}/__init__.py      |    0
 .../providers/asana/example_dags/example_asana.py  |   77 +
 .../providers/asana/hooks}/__init__.py             |    0
 airflow/providers/asana/hooks/asana.py             |  282 +++
 .../providers/asana/operators}/__init__.py         |    0
 airflow/providers/asana/operators/asana_tasks.py   |  170 ++
 .../providers/{postgres => asana}/provider.yaml    |   26 +-
 .../providers/cncf/kubernetes/backcompat/volume.py |    2 +-
 .../cncf/kubernetes/operators/kubernetes_pod.py    |   10 +-
 airflow/providers/docker/CHANGELOG.rst             |   16 +
 .../example_dags/example_docker_copy_data.py       |   10 +-
 airflow/providers/docker/operators/docker.py       |   16 +-
 airflow/providers/docker/operators/docker_swarm.py |    1 +
 airflow/providers/docker/provider.yaml             |    1 +
 .../providers/elasticsearch/log/es_task_handler.py |    2 +-
 airflow/providers/google/ads/hooks/ads.py          |   11 +-
 airflow/providers/google/ads/operators/ads.py      |   10 +-
 .../providers/google/ads/transfers/ads_to_gcs.py   |   10 +-
 airflow/providers/google/cloud/hooks/cloud_sql.py  |    4 +-
 .../providers/google/cloud/hooks/compute_ssh.py    |    2 +-
 airflow/providers/google/cloud/hooks/dataflow.py   |    2 +-
 airflow/providers/google/cloud/hooks/gcs.py        |    6 +-
 airflow/providers/google/cloud/hooks/gdm.py        |    2 +-
 .../google/cloud/transfers/gcs_to_bigquery.py      |    2 +-
 airflow/providers/google/provider.yaml             |    1 +
 airflow/providers/http/operators/http.py           |   10 +-
 airflow/providers/microsoft/azure/hooks/adx.py     |    6 +-
 .../providers/microsoft/azure/hooks/azure_batch.py |    2 +-
 airflow/providers/odbc/hooks/odbc.py               |    2 +-
 airflow/providers/oracle/hooks/oracle.py           |   34 +-
 airflow/providers/oracle/operators/oracle.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/slack/hooks/slack.py             |    8 +-
 .../snowflake/transfers/s3_to_snowflake.py         |   45 +-
 airflow/serialization/serialized_objects.py        |   12 +-
 airflow/settings.py                                |    9 +
 airflow/stats.py                                   |    2 +-
 .editorconfig => airflow/templates.py              |   37 +-
 airflow/ui/.env.example                            |   17 +
 airflow/ui/docs/CONTRIBUTING.md                    |    4 +-
 .../ui/src/components/AppContainer/AppHeader.tsx   |   14 +-
 .../components/AppContainer/TimezoneDropdown.tsx   |   16 +-
 .../{TimezoneProvider.tsx => DateProvider.tsx}     |   34 +-
 airflow/ui/src/providers/auth/PrivateRoute.tsx     |    6 +-
 airflow/ui/test/Login.test.tsx                     |    6 -
 airflow/ui/test/TimezoneDropdown.test.tsx          |   10 +-
 airflow/ui/tsconfig.json                           |    2 +-
 airflow/utils/dag_processing.py                    |    2 +-
 airflow/utils/db.py                                |    2 +-
 airflow/utils/decorators.py                        |    2 +-
 airflow/utils/log/file_task_handler.py             |    4 +-
 airflow/utils/log/secrets_masker.py                |    4 +-
 airflow/utils/process_utils.py                     |    4 +-
 airflow/utils/strings.py                           |    2 +-
 airflow/utils/task_group.py                        |    8 +-
 airflow/utils/timezone.py                          |    1 +
 airflow/www/app.py                                 |    4 +-
 airflow/www/extensions/init_views.py               |    4 +-
 airflow/www/package.json                           |    4 +-
 airflow/www/static/js/calendar.js                  |    2 +-
 airflow/www/static/js/dag.js                       |  264 ++
 airflow/www/static/js/dag_dependencies.js          |    3 +-
 airflow/www/static/js/dags.js                      |   14 +-
 airflow/www/static/js/gantt.js                     |    5 +-
 airflow/www/static/js/graph.js                     |   11 +-
 airflow/www/static/js/task_instances.js            |    7 +-
 airflow/www/static/js/tree.js                      |   13 +-
 airflow/www/templates/airflow/dag.html             |  262 +-
 airflow/www/templates/airflow/dags.html            |   10 +
 airflow/www/utils.py                               |    2 +-
 airflow/www/views.py                               |   25 +-
 airflow/www/webpack.config.js                      |    1 +
 airflow/www/yarn.lock                              | 1338 +++++-----
 breeze                                             |   48 +-
 breeze-complete                                    |    1 +
 chart/.gitignore                                   |    3 +
 chart/.helmignore                                  |    3 +
 chart/Chart.yaml                                   |   13 +-
 chart/INSTALL                                      |   14 +
 {provider_packages => chart}/LICENSE               |    0
 chart/NOTICE                                       |    6 +
 chart/README.md                                    |    4 +-
 chart/UPDATING.md                                  |   54 +
 chart/files/pod-template-file.kubernetes-helm-yaml |   44 +-
 chart/templates/NOTES.txt                          |   52 +-
 chart/templates/_helpers.yaml                      |   32 +-
 chart/templates/configmaps/configmap.yaml          |    8 +-
 chart/templates/flower/flower-deployment.yaml      |    4 +
 chart/templates/flower/flower-service.yaml         |    8 +-
 chart/templates/flower/flower-serviceaccount.yaml  |    1 +
 .../jobs/create-user-job-serviceaccount.yaml       |    1 +
 .../jobs/migrate-database-job-serviceaccount.yaml  |    1 +
 .../pgbouncer/pgbouncer-serviceaccount.yaml        |    1 +
 chart/templates/redis/redis-serviceaccount.yaml    |    1 +
 .../templates/scheduler/scheduler-deployment.yaml  |   11 +-
 .../scheduler/scheduler-serviceaccount.yaml        |    1 +
 chart/templates/secrets/fernetkey-secret.yaml      |    1 +
 .../secrets/metadata-connection-secret.yaml        |    1 +
 .../templates/secrets/pgbouncer-config-secret.yaml |    2 +
 .../templates/secrets/pgbouncer-stats-secret.yaml  |    2 +
 chart/templates/secrets/redis-secrets.yaml         |    4 +
 .../secrets/result-backend-connection-secret.yaml  |   12 +-
 chart/templates/statsd/statsd-serviceaccount.yaml  |    1 +
 .../templates/webserver/webserver-deployment.yaml  |   15 +-
 chart/templates/webserver/webserver-service.yaml   |    4 +-
 .../webserver/webserver-serviceaccount.yaml        |    1 +
 chart/templates/workers/worker-deployment.yaml     |   13 +-
 chart/templates/workers/worker-serviceaccount.yaml |    1 +
 chart/tests/test_airflow_common.py                 |   92 +
 chart/tests/test_basic_helm_chart.py               |   42 +-
 chart/tests/test_configmap.py                      |   62 +
 chart/tests/test_flower.py                         |   62 +-
 chart/tests/test_git_sync_scheduler.py             |   25 +-
 chart/tests/test_git_sync_webserver.py             |   69 +-
 chart/tests/test_git_sync_worker.py                |   17 +
 chart/tests/test_pgbouncer.py                      |   10 +-
 chart/tests/test_pod_template_file.py              |  100 +-
 .../tests/test_result_backend_connection_secret.py |   47 +-
 chart/tests/test_scheduler.py                      |   17 +
 ...t_webserver_deployment.py => test_webserver.py} |   56 +
 chart/tests/test_worker.py                         |   32 +
 chart/values.schema.json                           | 1581 ++++++++----
 chart/values.yaml                                  |   97 +-
 chart/values_schema.schema.json                    |   93 +
 clients/gen/common.sh                              |    2 +-
 clients/gen/python.sh                              |    2 +-
 codecov.yml                                        |    2 +
 dev/README_RELEASE_AIRFLOW.md                      |   66 +-
 dev/README_RELEASE_AIRFLOW_UPGRADE_CHECK.md        |    4 +-
 dev/README_RELEASE_PROVIDER_PACKAGES.md            |    6 +-
 dev/check_files.py                                 |    2 +-
 .../PROVIDER_INDEX_TEMPLATE.rst.jinja2             |   11 +
 dev/provider_packages/README.md                    |    2 +-
 dev/provider_packages/prepare_provider_packages.py |   53 +-
 dev/retag_docker_images.py                         |  105 +
 docs/README.rst                                    |   12 +
 .../connections/hiveserver2.rst                    |    2 +-
 .../commits.rst}                                   |   20 +-
 .../connections/asana.rst}                         |   45 +-
 docs/apache-airflow-providers-asana/index.rst      |  123 +
 .../operators/asana.rst                            |   88 +
 .../api-auth-backend/google-openid.rst             |    2 +-
 .../operators/leveldb/leveldb.rst                  |    7 +-
 .../connections/imap.rst                           |    2 +-
 .../connections/oracle.rst                         |   32 +-
 .../howto/create-update-providers.rst              |    4 +-
 docs/apache-airflow/best-practices.rst             |   18 +-
 docs/apache-airflow/concepts/dags.rst              |    3 +
 docs/apache-airflow/concepts/index.rst             |    1 +
 docs/apache-airflow/concepts/operators.rst         |    2 +-
 docs/apache-airflow/concepts/pools.rst             |   20 +-
 docs/apache-airflow/concepts/priority-weight.rst   |   61 +
 docs/apache-airflow/concepts/scheduler.rst         |    2 +
 docs/apache-airflow/executor/celery.rst            |    2 +
 docs/apache-airflow/extra-packages-ref.rst         |    8 +-
 docs/apache-airflow/faq.rst                        |  254 +-
 docs/apache-airflow/howto/custom-operator.rst      |    7 +
 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               |   74 +-
 docs/apache-airflow/macros-ref.rst                 |    2 +
 docs/apache-airflow/security/api.rst               |    2 +-
 docs/apache-airflow/start/docker.rst               |   13 +
 docs/apache-airflow/start/local.rst                |   52 +-
 docs/apache-airflow/tutorial.rst                   |    9 +-
 docs/conf.py                                       |  100 +-
 docs/docker-stack/build.rst                        |   14 +-
 .../{github-v2-0-test.sh => github-v2-1-test.sh}   |    2 +-
 .../restricted/restricted_environments.sh          |    3 +
 .../docker-images-recipes/hadoop.Dockerfile        |    1 +
 docs/docker-stack/entrypoint.rst                   |    2 +-
 docs/exts/docroles.py                              |    1 +
 docs/exts/docs_build/docs_builder.py               |    4 +-
 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/docs_build/third_party_inventories.py    |    3 +-
 docs/exts/extra_files_with_substitutions.py        |   19 +-
 docs/exts/substitution_extensions.py               |    2 +-
 docs/helm-chart/index.rst                          |   10 +-
 docs/helm-chart/keda.rst                           |    4 +-
 docs/helm-chart/manage-dags-files.rst              |   78 +-
 docs/helm-chart/manage-logs.rst                    |   10 +-
 docs/helm-chart/parameters-ref.rst                 |  593 +----
 docs/helm-chart/production-guide.rst               |  179 ++
 docs/helm-chart/quick-start.rst                    |   28 +-
 .../Postgress.png => postgres/Postgres.png}        |  Bin
 docs/spelling_wordlist.txt                         |   19 +-
 .../{test_kubernetes_executor.py => test_base.py}  |   69 +-
 kubernetes_tests/test_kubernetes_executor.py       |  206 +-
 kubernetes_tests/test_kubernetes_pod_operator.py   |    4 +
 .../test_kubernetes_pod_operator_backcompat.py     |   29 +-
 kubernetes_tests/test_other_executors.py           |   89 +
 licenses/LICENSE-connexion.txt                     |    9 +
 licenses/LICENSE-python-nvd3.txt                   |   24 -
 licenses/LICENSE-python-slugify.txt                |   21 -
 metastore_browser/hive_metastore.py                |    4 +-
 pylintrc                                           |    2 +-
 pylintrc-tests                                     |    2 +-
 scripts/ci/constraints/ci_branch_constraints.sh    |    2 +
 scripts/ci/images/ci_build_dockerhub.sh            |    7 +-
 ...tup_cluster_and_deploy_airflow_to_kubernetes.sh |    1 +
 ..._cluster_and_run_kubernetes_tests_single_job.sh |    1 +
 ...lusters_and_run_kubernetes_tests_in_parallel.sh |    1 -
 scripts/ci/libraries/_build_images.sh              |   13 +-
 scripts/ci/libraries/_initialization.sh            |    8 +-
 scripts/ci/libraries/_kind.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/_script_init.sh               |    9 +-
 scripts/ci/libraries/_testing.sh                   |    2 +-
 scripts/ci/pre_commit/pre_commit_json_schema.py    |   19 +-
 scripts/ci/selective_ci_checks.sh                  |    2 +-
 scripts/docker/common.sh                           |    9 +
 scripts/docker/install_additional_dependencies.sh  |    8 +
 scripts/docker/install_airflow.sh                  |    2 +-
 scripts/docker/install_airflow_from_branch_tip.sh  |    2 +
 .../docker/install_from_docker_context_files.sh    |    2 +
 scripts/docker/install_pip_version.sh              |   40 +
 scripts/in_container/_in_container_utils.sh        |  111 -
 scripts/in_container/prod/entrypoint_prod.sh       |    7 +
 .../run_install_and_test_provider_packages.sh      |    8 +-
 scripts/in_container/run_mypy.sh                   |    2 -
 .../in_container/run_prepare_airflow_packages.sh   |   26 +-
 .../run_prepare_provider_documentation.sh          |    4 +-
 .../in_container/run_prepare_provider_packages.sh  |   28 +-
 .../in_container/update_quarantined_test_status.py |    2 +-
 setup.cfg                                          |   25 +-
 setup.py                                           |   46 +-
 .../endpoints/test_task_instance_endpoint.py       |   20 +
 tests/cli/commands/test_info_command.py            |   29 +-
 tests/cli/commands/test_task_command.py            |   61 +
 tests/cli/commands/test_user_command.py            |   78 +
 tests/core/test_core.py                            |    2 +-
 tests/core/test_core_to_contrib.py                 |    3 +-
 tests/core/test_logging_config.py                  |    2 +
 tests/core/test_providers_manager.py               |    5 +
 tests/core/test_sqlalchemy_config.py               |    5 +
 .editorconfig => tests/core/test_templates.py      |   38 +-
 tests/executors/test_kubernetes_executor.py        |   25 +
 tests/hooks/test_dbapi.py                          |   36 +-
 tests/hooks/test_subprocess.py                     |    2 +-
 tests/jobs/test_backfill_job.py                    |    2 +-
 tests/jobs/test_local_task_job.py                  |    1 +
 tests/jobs/test_scheduler_job.py                   |   10 +-
 tests/models/test_baseoperator.py                  |    2 +-
 tests/models/test_dagrun.py                        |    2 +-
 tests/operators/test_python.py                     |   13 +
 tests/providers/amazon/aws/hooks/test_datasync.py  |    2 +-
 .../amazon/aws/log/test_cloudwatch_task_handler.py |   32 +-
 .../amazon/aws/operators/test_s3_delete_objects.py |    4 +-
 .../amazon/aws/transfers/test_mongo_to_s3.py       |    4 +-
 tests/providers/apache/druid/hooks/test_druid.py   |    2 +-
 tests/providers/apache/hive/hooks/test_hive.py     |    2 +-
 .../apache/hive/transfers/test_s3_to_hive.py       |   10 +-
 tests/providers/apache/pinot/hooks/test_pinot.py   |    2 +-
 .../experimental => providers/asana}/__init__.py   |    0
 .../asana/hooks}/__init__.py                       |    0
 tests/providers/asana/hooks/test_asana.py          |  254 ++
 .../asana/operators}/__init__.py                   |    0
 .../providers/asana/operators/test_asana_tasks.py  |  102 +
 .../kubernetes/operators/test_kubernetes_pod.py    |   75 +-
 tests/providers/docker/operators/test_docker.py    |   10 +-
 .../docker/operators/test_docker_swarm.py          |    3 +
 .../elasticsearch/hooks/test_elasticsearch.py      |    2 +-
 tests/providers/exasol/hooks/test_exasol.py        |    2 +-
 tests/providers/google/ads/operators/test_ads.py   |    8 +-
 .../google/ads/transfers/test_ads_to_gcs.py        |    8 +-
 .../providers/google/cloud/hooks/test_dataflow.py  |    2 +-
 .../google/cloud/operators/test_dataflow_system.py |    3 +-
 .../google/cloud/operators/test_dataproc.py        |   20 +-
 tests/providers/http/sensors/test_http.py          |   14 +-
 tests/providers/mysql/hooks/test_mysql.py          |    2 +-
 tests/providers/odbc/hooks/test_odbc.py            |    9 +-
 tests/providers/oracle/hooks/test_oracle.py        |   27 +-
 tests/providers/oracle/operators/test_oracle.py    |   10 +-
 tests/providers/postgres/hooks/test_postgres.py    |    2 +-
 tests/providers/presto/hooks/test_presto.py        |    2 +-
 tests/providers/qubole/hooks/test_qubole.py        |   44 +-
 tests/providers/qubole/operators/test_qubole.py    |   18 +-
 tests/providers/snowflake/hooks/test_snowflake.py  |    4 +-
 .../snowflake/transfers/test_s3_to_snowflake.py    |   31 +-
 tests/providers/sqlite/hooks/test_sqlite.py        |    2 +-
 tests/providers/trino/hooks/test_trino.py          |    2 +-
 tests/providers/vertica/hooks/test_vertica.py      |    2 +-
 tests/test_utils/logging_command_executor.py       |   10 +-
 tests/test_utils/perf/dags/elastic_dag.py          |    4 +-
 .../perf/scheduler_dag_execution_timing.py         |    2 +-
 tests/test_utils/perf/scheduler_ops_metrics.py     |    2 +-
 tests/utils/log/test_secrets_masker.py             |    4 +-
 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_views.py                            | 2632 --------------------
 tests/www/views/conftest.py                        |    5 +
 tests/www/views/test_views.py                      |    5 +
 tests/www/views/test_views_acl.py                  |  779 ++++++
 tests/www/views/test_views_base.py                 |  437 ++++
 tests/www/views/test_views_decorators.py           |   17 +-
 tests/www/views/test_views_graph_gantt.py          |  206 ++
 tests/www/views/test_views_log.py                  |  405 +++
 tests/www/views/test_views_tasks.py                |  576 +++++
 425 files changed, 16296 insertions(+), 6300 deletions(-)
 copy scripts/ci/docker-compose/empty/.gitignore => airflow/_vendor/__init__.py (100%)
 create mode 100755 airflow/_vendor/connexion/__init__.py
 create mode 100644 airflow/_vendor/connexion/__main__.py
 create mode 100644 airflow/_vendor/connexion/apis/__init__.py
 create mode 100644 airflow/_vendor/connexion/apis/abstract.py
 create mode 100644 airflow/_vendor/connexion/apis/aiohttp_api.py
 create mode 100644 airflow/_vendor/connexion/apis/flask_api.py
 create mode 100644 airflow/_vendor/connexion/apis/flask_utils.py
 create mode 100644 airflow/_vendor/connexion/apps/__init__.py
 create mode 100644 airflow/_vendor/connexion/apps/abstract.py
 create mode 100644 airflow/_vendor/connexion/apps/aiohttp_app.py
 create mode 100644 airflow/_vendor/connexion/apps/flask_app.py
 create mode 100644 airflow/_vendor/connexion/cli.py
 copy scripts/ci/docker-compose/empty/.gitignore => airflow/_vendor/connexion/decorators/__init__.py (100%)
 create mode 100644 airflow/_vendor/connexion/decorators/coroutine_wrappers.py
 create mode 100644 airflow/_vendor/connexion/decorators/decorator.py
 create mode 100644 airflow/_vendor/connexion/decorators/metrics.py
 create mode 100644 airflow/_vendor/connexion/decorators/parameter.py
 create mode 100644 airflow/_vendor/connexion/decorators/produces.py
 create mode 100644 airflow/_vendor/connexion/decorators/response.py
 create mode 100644 airflow/_vendor/connexion/decorators/security.py
 create mode 100644 airflow/_vendor/connexion/decorators/uri_parsing.py
 create mode 100644 airflow/_vendor/connexion/decorators/validation.py
 create mode 100644 airflow/_vendor/connexion/exceptions.py
 create mode 100644 airflow/_vendor/connexion/handlers.py
 create mode 100644 airflow/_vendor/connexion/http_facts.py
 create mode 100644 airflow/_vendor/connexion/json_schema.py
 create mode 100644 airflow/_vendor/connexion/jsonifier.py
 create mode 100644 airflow/_vendor/connexion/lifecycle.py
 create mode 100644 airflow/_vendor/connexion/mock.py
 create mode 100644 airflow/_vendor/connexion/operations/__init__.py
 create mode 100644 airflow/_vendor/connexion/operations/abstract.py
 create mode 100644 airflow/_vendor/connexion/operations/compat.py
 create mode 100644 airflow/_vendor/connexion/operations/openapi.py
 create mode 100644 airflow/_vendor/connexion/operations/secure.py
 create mode 100644 airflow/_vendor/connexion/operations/swagger2.py
 create mode 100644 airflow/_vendor/connexion/options.py
 create mode 100644 airflow/_vendor/connexion/problem.py
 create mode 100644 airflow/_vendor/connexion/resolver.py
 create mode 100644 airflow/_vendor/connexion/setup.cfg
 create mode 100755 airflow/_vendor/connexion/setup.py
 create mode 100644 airflow/_vendor/connexion/spec.py
 create mode 100644 airflow/_vendor/connexion/utils.py
 create mode 100644 airflow/cli/commands/standalone_command.py
 copy docs/apache-airflow/concepts/index.rst => airflow/providers/asana/CHANGELOG.rst (60%)
 copy airflow/providers/{neo4j => asana}/README.md (100%)
 copy {tests/www/api/experimental => airflow/providers/asana}/__init__.py (100%)
 copy {tests/www/api/experimental => airflow/providers/asana/example_dags}/__init__.py (100%)
 create mode 100644 airflow/providers/asana/example_dags/example_asana.py
 copy {tests/www/api/experimental => airflow/providers/asana/hooks}/__init__.py (100%)
 create mode 100644 airflow/providers/asana/hooks/asana.py
 copy {tests/www/api/experimental => airflow/providers/asana/operators}/__init__.py (100%)
 create mode 100644 airflow/providers/asana/operators/asana_tasks.py
 copy airflow/providers/{postgres => asana}/provider.yaml (61%)
 copy .editorconfig => airflow/templates.py (58%)
 rename airflow/ui/src/providers/{TimezoneProvider.tsx => DateProvider.tsx} (66%)
 create mode 100644 airflow/www/static/js/dag.js
 create mode 100644 chart/INSTALL
 copy {provider_packages => chart}/LICENSE (100%)
 create mode 100644 chart/NOTICE
 create mode 100644 chart/UPDATING.md
 create mode 100644 chart/tests/test_airflow_common.py
 create mode 100644 chart/tests/test_configmap.py
 rename chart/tests/{test_webserver_deployment.py => test_webserver.py} (81%)
 create mode 100644 chart/values_schema.schema.json
 create mode 100755 dev/retag_docker_images.py
 rename docs/{helm-chart/external-redis.rst => apache-airflow-providers-asana/commits.rst} (60%)
 copy docs/{apache-airflow/concepts/index.rst => apache-airflow-providers-asana/connections/asana.rst} (60%)
 create mode 100644 docs/apache-airflow-providers-asana/index.rst
 create mode 100644 docs/apache-airflow-providers-asana/operators/asana.rst
 create mode 100644 docs/apache-airflow/concepts/priority-weight.rst
 create mode 100644 docs/apache-airflow/img/dag_doc.png
 create mode 100644 docs/apache-airflow/img/task_doc.png
 rename docs/docker-stack/docker-examples/customizing/{github-v2-0-test.sh => github-v2-1-test.sh} (95%)
 create mode 100644 docs/helm-chart/production-guide.rst
 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
 create mode 100644 licenses/LICENSE-connexion.txt
 delete mode 100644 licenses/LICENSE-python-nvd3.txt
 delete mode 100644 licenses/LICENSE-python-slugify.txt
 create mode 100755 scripts/docker/install_pip_version.sh
 copy .editorconfig => tests/core/test_templates.py (60%)
 copy tests/{www/api/experimental => providers/asana}/__init__.py (100%)
 copy tests/{www/api/experimental => providers/asana/hooks}/__init__.py (100%)
 create mode 100644 tests/providers/asana/hooks/test_asana.py
 copy tests/{www/api/experimental => providers/asana/operators}/__init__.py (100%)
 create mode 100644 tests/providers/asana/operators/test_asana_tasks.py
 delete mode 100644 tests/www/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_graph_gantt.py
 create mode 100644 tests/www/views/test_views_log.py
 create mode 100644 tests/www/views/test_views_tasks.py