You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by el...@apache.org on 2023/03/10 16:52:33 UTC

[airflow-site] branch main updated: Add documentation for packages - 2023-03-07 (#748)

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

eladkal pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/airflow-site.git


The following commit(s) were added to refs/heads/main by this push:
     new 8af22eaeaa Add documentation for packages - 2023-03-07 (#748)
8af22eaeaa is described below

commit 8af22eaeaa9d0bb7bf15eab5783d3ff1ef5d1c46
Author: eladkal <45...@users.noreply.github.com>
AuthorDate: Fri Mar 10 18:52:26 2023 +0200

    Add documentation for packages - 2023-03-07 (#748)
---
 .../providers/hashicorp/hooks/vault/index.rst.txt  | 176 ++++++++++++
 .../_api/airflow/providers/hashicorp/index.rst.txt |  16 ++
 .../hashicorp/secrets/vault/index.rst.txt          | 126 +++++++++
 .../3.3.0/_sources/commits.rst.txt                 | 294 +++++++++++++++++++++
 .../secrets-backends/hashicorp-vault.rst.txt       | 216 +++++++++++++++
 .../3.3.0/objects.inv                              | Bin 0 -> 690 bytes
 .../3.3.0/searchindex.js                           |   1 +
 .../3.3.0/secrets-backends/index.html              |   1 +
 .../apache-airflow-providers-hashicorp/stable.txt  |   2 +-
 9 files changed, 831 insertions(+), 1 deletion(-)

diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/hooks/vault/index.rst.txt b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/hooks/vault/index.rst.txt
new file mode 100644
index 0000000000..1edd30e2ac
--- /dev/null
+++ b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/hooks/vault/index.rst.txt
@@ -0,0 +1,176 @@
+:py:mod:`airflow.providers.hashicorp.hooks.vault`
+=================================================
+
+.. py:module:: airflow.providers.hashicorp.hooks.vault
+
+.. autoapi-nested-parse::
+
+   Hook for HashiCorp Vault
+
+
+
+Module Contents
+---------------
+
+Classes
+~~~~~~~
+
+.. autoapisummary::
+
+   airflow.providers.hashicorp.hooks.vault.VaultHook
+
+
+
+
+.. py:class:: VaultHook(vault_conn_id = default_conn_name, auth_type = None, auth_mount_point = None, kv_engine_version = None, role_id = None, kubernetes_role = None, kubernetes_jwt_path = None, token_path = None, gcp_key_path = None, gcp_scopes = None, azure_tenant_id = None, azure_resource = None, radius_host = None, radius_port = None, **kwargs)
+
+   Bases: :py:obj:`airflow.hooks.base.BaseHook`
+
+   Hook to Interact with HashiCorp Vault KeyValue Secret engine.
+
+   HashiCorp hvac documentation:
+      * https://hvac.readthedocs.io/en/stable/
+
+   You connect to the host specified as host in the connection. The login/password from the connection
+   are used as credentials usually and you can specify different authentication parameters
+   via init params or via corresponding extras in the connection.
+
+   The mount point should be placed as a path in the URL - similarly to Vault's URL schema:
+   This indicates the "path" the secret engine is mounted on. Default id not specified is "secret".
+   Note that this ``mount_point`` is not used for authentication if authentication is done via a
+   different engines. Each engine uses it's own engine-specific authentication mount_point.
+
+   The extras in the connection are named the same as the parameters ('kv_engine_version', 'auth_type', ...).
+
+   You can also use gcp_keyfile_dict extra to pass json-formatted dict in case of 'gcp' authentication.
+
+   The URL schemas supported are "vault", "http" (using http to connect to the vault) or
+   "vaults" and "https" (using https to connect to the vault).
+
+   Example URL:
+
+   .. code-block::
+
+       vault://user:password@host:port/mount_point?kv_engine_version=1&auth_type=github
+
+
+   Login/Password are used as credentials:
+
+       * approle: login -> role_id,  password -> secret_id
+       * github: password -> token
+       * token: password -> token
+       * aws_iam: login -> key_id, password -> secret_id
+       * azure: login -> client_id, password -> client_secret
+       * ldap: login -> username,   password -> password
+       * userpass: login -> username, password -> password
+       * radius: password -> radius_secret
+
+   :param vault_conn_id: The id of the connection to use
+   :param auth_type: Authentication Type for the Vault. Default is ``token``. Available values are:
+       ('approle', 'github', 'gcp', 'kubernetes', 'ldap', 'token', 'userpass')
+   :param auth_mount_point: It can be used to define mount_point for authentication chosen
+         Default depends on the authentication method used.
+   :param kv_engine_version: Select the version of the engine to run (``1`` or ``2``). Defaults to
+         version defined in connection or ``2`` if not defined in connection.
+   :param role_id: Role ID for ``aws_iam`` Authentication.
+   :param kubernetes_role: Role for Authentication (for ``kubernetes`` auth_type)
+   :param kubernetes_jwt_path: Path for kubernetes jwt token (for ``kubernetes`` auth_type, default:
+       ``/var/run/secrets/kubernetes.io/serviceaccount/token``)
+   :param token_path: path to file containing authentication token to include in requests sent to Vault
+       (for ``token`` and ``github`` auth_type).
+   :param gcp_key_path: Path to Google Cloud Service Account key file (JSON) (for ``gcp`` auth_type)
+          Mutually exclusive with gcp_keyfile_dict
+   :param gcp_scopes: Comma-separated string containing OAuth2  scopes (for ``gcp`` auth_type)
+   :param azure_tenant_id: The tenant id for the Azure Active Directory (for ``azure`` auth_type)
+   :param azure_resource: The configured URL for the application registered in Azure Active Directory
+          (for ``azure`` auth_type)
+   :param radius_host: Host for radius (for ``radius`` auth_type)
+   :param radius_port: Port for radius (for ``radius`` auth_type)
+
+
+   .. py:attribute:: conn_name_attr
+      :value: 'vault_conn_id'
+
+      
+
+   .. py:attribute:: default_conn_name
+      :value: 'vault_default'
+
+      
+
+   .. py:attribute:: conn_type
+      :value: 'vault'
+
+      
+
+   .. py:attribute:: hook_name
+      :value: 'Hashicorp Vault'
+
+      
+
+   .. py:method:: get_conn()
+
+      Retrieves connection to Vault.
+
+      :return: connection used.
+
+
+   .. py:method:: get_secret(secret_path, secret_version = None)
+
+      Get secret value from the engine.
+
+      :param secret_path: Path of the secret
+      :param secret_version: Optional version of key to read - can only be used in case of version 2 of KV
+
+      See https://hvac.readthedocs.io/en/stable/usage/secrets_engines/kv_v1.html
+      and https://hvac.readthedocs.io/en/stable/usage/secrets_engines/kv_v2.html for details.
+
+      :param secret_path: Path of the secret
+      :return: secret stored in the vault as a dictionary
+
+
+   .. py:method:: get_secret_metadata(secret_path)
+
+      Reads secret metadata (including versions) from the engine. It is only valid for KV version 2.
+
+      :param secret_path: Path to read from
+      :return: secret metadata. This is a Dict containing metadata for the secret.
+
+      See https://hvac.readthedocs.io/en/stable/usage/secrets_engines/kv_v2.html for details.
+
+
+
+   .. py:method:: get_secret_including_metadata(secret_path, secret_version = None)
+
+      Reads secret including metadata. It is only valid for KV version 2.
+
+      See https://hvac.readthedocs.io/en/stable/usage/secrets_engines/kv_v2.html for details.
+
+      :param secret_path: Path of the secret
+      :param secret_version: Optional version of key to read - can only be used in case of version 2 of KV
+      :return: key info. This is a Dict with "data" mapping keeping secret
+          and "metadata" mapping keeping metadata of the secret.
+
+
+
+   .. py:method:: create_or_update_secret(secret_path, secret, method = None, cas = None)
+
+      Creates or updates secret.
+
+      :param secret_path: Path to read from
+      :param secret: Secret to create or update for the path specified
+      :param method: Optional parameter to explicitly request a POST (create) or PUT (update) request to
+          the selected kv secret engine. If no argument is provided for this parameter, hvac attempts to
+          intelligently determine which method is appropriate. Only valid for KV engine version 1
+      :param cas: Set the "cas" value to use a Check-And-Set operation. If not set the write will be
+          allowed. If set to 0 a write will only be allowed if the key doesn't exist.
+          If the index is non-zero the write will only be allowed if the key's current version
+          matches the version specified in the cas parameter. Only valid for KV engine version 2.
+      :return: The response of the create_or_update_secret request.
+
+      See https://hvac.readthedocs.io/en/stable/usage/secrets_engines/kv_v1.html
+      and https://hvac.readthedocs.io/en/stable/usage/secrets_engines/kv_v2.html for details.
+
+
+
+
diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/index.rst.txt b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/index.rst.txt
new file mode 100644
index 0000000000..303e5c8be8
--- /dev/null
+++ b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/index.rst.txt
@@ -0,0 +1,16 @@
+:py:mod:`airflow.providers.hashicorp`
+=====================================
+
+.. py:module:: airflow.providers.hashicorp
+
+
+Subpackages
+-----------
+.. toctree::
+   :titlesonly:
+   :maxdepth: 3
+
+   hooks/index.rst
+   secrets/index.rst
+
+
diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/secrets/vault/index.rst.txt b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/secrets/vault/index.rst.txt
new file mode 100644
index 0000000000..d123b05dd8
--- /dev/null
+++ b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/_api/airflow/providers/hashicorp/secrets/vault/index.rst.txt
@@ -0,0 +1,126 @@
+:py:mod:`airflow.providers.hashicorp.secrets.vault`
+===================================================
+
+.. py:module:: airflow.providers.hashicorp.secrets.vault
+
+.. autoapi-nested-parse::
+
+   Objects relating to sourcing connections & variables from Hashicorp Vault
+
+
+
+Module Contents
+---------------
+
+Classes
+~~~~~~~
+
+.. autoapisummary::
+
+   airflow.providers.hashicorp.secrets.vault.VaultBackend
+
+
+
+
+.. py:class:: VaultBackend(connections_path = 'connections', variables_path = 'variables', config_path = 'config', url = None, auth_type = 'token', auth_mount_point = None, mount_point = 'secret', kv_engine_version = 2, token = None, token_path = None, username = None, password = None, key_id = None, secret_id = None, role_id = None, kubernetes_role = None, kubernetes_jwt_path = '/var/run/secrets/kubernetes.io/serviceaccount/token', gcp_key_path = None, gcp_keyfile_dict = None, gcp_scope [...]
+
+   Bases: :py:obj:`airflow.secrets.BaseSecretsBackend`, :py:obj:`airflow.utils.log.logging_mixin.LoggingMixin`
+
+   Retrieves Connections and Variables from Hashicorp Vault.
+
+   Configurable via ``airflow.cfg`` as follows:
+
+   .. code-block:: ini
+
+       [secrets]
+       backend = airflow.providers.hashicorp.secrets.vault.VaultBackend
+       backend_kwargs = {
+           "connections_path": "connections",
+           "url": "http://127.0.0.1:8200",
+           "mount_point": "airflow"
+           }
+
+   For example, if your keys are under ``connections`` path in ``airflow`` mount_point, this
+   would be accessible if you provide ``{"connections_path": "connections"}`` and request
+   conn_id ``smtp_default``.
+
+   :param connections_path: Specifies the path of the secret to read to get Connections.
+       (default: 'connections'). If set to None (null), requests for connections will not be sent to Vault.
+   :param variables_path: Specifies the path of the secret to read to get Variable.
+       (default: 'variables'). If set to None (null), requests for variables will not be sent to Vault.
+   :param config_path: Specifies the path of the secret to read Airflow Configurations
+       (default: 'config'). If set to None (null), requests for configurations will not be sent to Vault.
+   :param url: Base URL for the Vault instance being addressed.
+   :param auth_type: Authentication Type for Vault. Default is ``token``. Available values are:
+       ('approle', 'aws_iam', 'azure', 'github', 'gcp', 'kubernetes', 'ldap', 'radius', 'token', 'userpass')
+   :param auth_mount_point: It can be used to define mount_point for authentication chosen
+         Default depends on the authentication method used.
+   :param mount_point: The "path" the secret engine was mounted on. Default is "secret". Note that
+        this mount_point is not used for authentication if authentication is done via a
+        different engine. If set to None, the mount secret should be provided as a prefix for each
+        variable/connection_id. For authentication mount_points see, auth_mount_point.
+   :param kv_engine_version: Select the version of the engine to run (``1`` or ``2``, default: ``2``).
+   :param token: Authentication token to include in requests sent to Vault.
+       (for ``token`` and ``github`` auth_type)
+   :param token_path: path to file containing authentication token to include in requests sent to Vault
+       (for ``token`` and ``github`` auth_type).
+   :param username: Username for Authentication (for ``ldap`` and ``userpass`` auth_type).
+   :param password: Password for Authentication (for ``ldap`` and ``userpass`` auth_type).
+   :param key_id: Key ID for Authentication (for ``aws_iam`` and ''azure`` auth_type).
+   :param secret_id: Secret ID for Authentication (for ``approle``, ``aws_iam`` and ``azure`` auth_types).
+   :param role_id: Role ID for Authentication (for ``approle``, ``aws_iam`` auth_types).
+   :param kubernetes_role: Role for Authentication (for ``kubernetes`` auth_type).
+   :param kubernetes_jwt_path: Path for kubernetes jwt token (for ``kubernetes`` auth_type, default:
+       ``/var/run/secrets/kubernetes.io/serviceaccount/token``).
+   :param gcp_key_path: Path to Google Cloud Service Account key file (JSON) (for ``gcp`` auth_type).
+          Mutually exclusive with gcp_keyfile_dict.
+   :param gcp_keyfile_dict: Dictionary of keyfile parameters. (for ``gcp`` auth_type).
+          Mutually exclusive with gcp_key_path.
+   :param gcp_scopes: Comma-separated string containing OAuth2 scopes (for ``gcp`` auth_type).
+   :param azure_tenant_id: The tenant id for the Azure Active Directory (for ``azure`` auth_type).
+   :param azure_resource: The configured URL for the application registered in Azure Active Directory
+          (for ``azure`` auth_type).
+   :param radius_host: Host for radius (for ``radius`` auth_type).
+   :param radius_secret: Secret for radius (for ``radius`` auth_type).
+   :param radius_port: Port for radius (for ``radius`` auth_type).
+
+   .. py:method:: get_response(conn_id)
+
+      Get data from Vault
+
+      :return: The data from the Vault path if exists
+
+
+   .. py:method:: get_conn_uri(conn_id)
+
+      Get serialized representation of connection
+
+      :param conn_id: The connection id
+      :return: The connection uri retrieved from the secret
+
+
+   .. py:method:: get_connection(conn_id)
+
+      Get connection from Vault as secret. Prioritize conn_uri if exists,
+      if not fall back to normal Connection creation.
+
+      :return: A Connection object constructed from Vault data
+
+
+   .. py:method:: get_variable(key)
+
+      Get Airflow Variable
+
+      :param key: Variable Key
+      :return: Variable Value retrieved from the vault
+
+
+   .. py:method:: get_config(key)
+
+      Get Airflow Configuration
+
+      :param key: Configuration Option Key
+      :return: Configuration Option Value retrieved from the vault
+
+
+
diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/commits.rst.txt b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/commits.rst.txt
new file mode 100644
index 0000000000..7ea1d36797
--- /dev/null
+++ b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/commits.rst.txt
@@ -0,0 +1,294 @@
+
+ .. Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+ ..   http://www.apache.org/licenses/LICENSE-2.0
+
+ .. Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+
+Package apache-airflow-providers-hashicorp
+------------------------------------------------------
+
+Hashicorp including `Hashicorp Vault <https://www.vaultproject.io/>`__
+
+
+This is detailed commit list of changes for versions provider package: ``hashicorp``.
+For high-level changelog, see :doc:`package information including changelog <index>`.
+
+
+
+3.3.0
+.....
+
+Latest change: 2023-03-04
+
+=================================================================================================  ===========  ==================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ==================================================================
+`4fa91d7540 <https://github.com/apache/airflow/commit/4fa91d7540b93420a6c7c43737e3ac881b418873>`_  2023-03-04   ``Fix empty paths in Vault secrets backend (#29908)``
+`fcd3c0149f <https://github.com/apache/airflow/commit/fcd3c0149f17b364dfb94c0523d23e3145976bbe>`_  2023-03-03   ``Prepare docs for 03/2023 wave of Providers (#29878)``
+`dff425bc3d <https://github.com/apache/airflow/commit/dff425bc3d92697bb447010aa9f3b56519a59f1e>`_  2023-02-24   ``Support multiple mount points in Vault backend secret (#29734)``
+=================================================================================================  ===========  ==================================================================
+
+3.2.0
+.....
+
+Latest change: 2022-11-15
+
+=================================================================================================  ===========  ====================================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ====================================================================================
+`12c3c39d1a <https://github.com/apache/airflow/commit/12c3c39d1a816c99c626fe4c650e88cf7b1cc1bc>`_  2022-11-15   ``pRepare docs for November 2022 wave of Providers (#27613)``
+`1a3f7857f5 <https://github.com/apache/airflow/commit/1a3f7857f50170cbef767b91e2831fee8019e7b1>`_  2022-11-02   ``Pass kwargs from vault hook to hvac client (#26680)``
+`9ab1a6a3e7 <https://github.com/apache/airflow/commit/9ab1a6a3e70b32a3cddddf0adede5d2f3f7e29ea>`_  2022-10-27   ``Update old style typing (#26872)``
+`78b8ea2f22 <https://github.com/apache/airflow/commit/78b8ea2f22239db3ef9976301234a66e50b47a94>`_  2022-10-24   ``Move min airflow version to 2.3.0 for all providers (#27196)``
+`2a34dc9e84 <https://github.com/apache/airflow/commit/2a34dc9e8470285b0ed2db71109ef4265e29688b>`_  2022-10-23   ``Enable string normalization in python formatting - providers (#27205)``
+`f8db64c35c <https://github.com/apache/airflow/commit/f8db64c35c8589840591021a48901577cff39c07>`_  2022-09-28   ``Update docs for September Provider's release (#26731)``
+`06acf40a43 <https://github.com/apache/airflow/commit/06acf40a4337759797f666d5bb27a5a393b74fed>`_  2022-09-13   ``Apply PEP-563 (Postponed Evaluation of Annotations) to non-core airflow (#26289)``
+`1a1f352479 <https://github.com/apache/airflow/commit/1a1f352479d6dbff21d73d3c51b1e5d5188e00e3>`_  2022-08-23   ``Add Airflow specific warning classes (#25799)``
+=================================================================================================  ===========  ====================================================================================
+
+3.1.0
+.....
+
+Latest change: 2022-08-10
+
+=================================================================================================  ===========  ================================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ================================================================================
+`e5ac6c7cfb <https://github.com/apache/airflow/commit/e5ac6c7cfb189c33e3b247f7d5aec59fe5e89a00>`_  2022-08-10   ``Prepare docs for new providers release (August 2022) (#25618)``
+`ad0a4965aa <https://github.com/apache/airflow/commit/ad0a4965aaf0702f0e8408660b912e87d3c75c22>`_  2022-07-28   ``Use newer kubernetes authentication method in internal vault client (#25351)``
+=================================================================================================  ===========  ================================================================================
+
+3.0.1
+.....
+
+Latest change: 2022-07-13
+
+=================================================================================================  ===========  =============================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  =============================================================================
+`d2459a241b <https://github.com/apache/airflow/commit/d2459a241b54d596ebdb9d81637400279fff4f2d>`_  2022-07-13   ``Add documentation for July 2022 Provider's release (#25030)``
+`0de31bd73a <https://github.com/apache/airflow/commit/0de31bd73a8f41dded2907f0dee59dfa6c1ed7a1>`_  2022-06-29   ``Move provider dependencies to inside provider folders (#24672)``
+`510a6bab45 <https://github.com/apache/airflow/commit/510a6bab4595cce8bd5b1447db957309d70f35d9>`_  2022-06-28   ``Remove 'hook-class-names' from provider.yaml (#24702)``
+`9c59831ee7 <https://github.com/apache/airflow/commit/9c59831ee78f14de96421c74986933c494407afa>`_  2022-06-21   ``Update providers to use functools compat for ''cached_property'' (#24582)``
+=================================================================================================  ===========  =============================================================================
+
+3.0.0
+.....
+
+Latest change: 2022-06-09
+
+=================================================================================================  ===========  ==================================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ==================================================================================
+`dcdcf3a2b8 <https://github.com/apache/airflow/commit/dcdcf3a2b8054fa727efb4cd79d38d2c9c7e1bd5>`_  2022-06-09   ``Update release notes for RC2 release of Providers for May 2022 (#24307)``
+`717a7588bc <https://github.com/apache/airflow/commit/717a7588bc8170363fea5cb75f17efcf68689619>`_  2022-06-07   ``Update package description to remove double min-airflow specification (#24292)``
+`b1ad017cee <https://github.com/apache/airflow/commit/b1ad017cee66f5e042144cc7baa2d44b23b47c4f>`_  2022-06-07   ``pydocstyle D202 added (#24221)``
+`aeabe994b3 <https://github.com/apache/airflow/commit/aeabe994b3381d082f75678a159ddbb3cbf6f4d3>`_  2022-06-07   ``Prepare docs for May 2022 provider's release (#24231)``
+`027b707d21 <https://github.com/apache/airflow/commit/027b707d215a9ff1151717439790effd44bab508>`_  2022-06-05   ``Add explanatory note for contributors about updating Changelog (#24229)``
+`75c60923e0 <https://github.com/apache/airflow/commit/75c60923e01375ffc5f71c4f2f7968f489e2ca2f>`_  2022-05-12   ``Prepare provider documentation 2022.05.11 (#23631)``
+`428a439953 <https://github.com/apache/airflow/commit/428a43995390b3623a51aa7bac7e21da69a8db22>`_  2022-05-09   ``Clean up in-line f-string concatenation (#23591)``
+`8b6b0848a3 <https://github.com/apache/airflow/commit/8b6b0848a3cacf9999477d6af4d2a87463f03026>`_  2022-04-23   ``Use new Breese for building, pulling and verifying the images. (#23104)``
+=================================================================================================  ===========  ==================================================================================
+
+2.2.0
+.....
+
+Latest change: 2022-04-07
+
+=================================================================================================  ===========  ==================================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ==================================================================================
+`56ab82ed7a <https://github.com/apache/airflow/commit/56ab82ed7a5c179d024722ccc697b740b2b93b6a>`_  2022-04-07   ``Prepare mid-April provider documentation. (#22819)``
+`7ab45d41d6 <https://github.com/apache/airflow/commit/7ab45d41d6c4de322dc8afe8a74b712d0bae4ee7>`_  2022-03-24   ``Update secrets backends to use get_conn_value instead of get_conn_uri (#22348)``
+=================================================================================================  ===========  ==================================================================================
+
+2.1.4
+.....
+
+Latest change: 2022-03-22
+
+=================================================================================================  ===========  ==============================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ==============================================================
+`d7dbfb7e26 <https://github.com/apache/airflow/commit/d7dbfb7e26a50130d3550e781dc71a5fbcaeb3d2>`_  2022-03-22   ``Add documentation for bugfix release of Providers (#22383)``
+=================================================================================================  ===========  ==============================================================
+
+2.1.3
+.....
+
+Latest change: 2022-03-14
+
+=================================================================================================  ===========  ====================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ====================================================================
+`16adc035b1 <https://github.com/apache/airflow/commit/16adc035b1ecdf533f44fbb3e32bea972127bb71>`_  2022-03-14   ``Add documentation for Classifier release for March 2022 (#22226)``
+=================================================================================================  ===========  ====================================================================
+
+2.1.2
+.....
+
+Latest change: 2022-03-07
+
+=================================================================================================  ===========  ==========================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ==========================================================================
+`f5b96315fe <https://github.com/apache/airflow/commit/f5b96315fe65b99c0e2542831ff73a3406c4232d>`_  2022-03-07   ``Add documentation for Feb Providers release (#22056)``
+`d94fa37830 <https://github.com/apache/airflow/commit/d94fa378305957358b910cfb1fe7cb14bc793804>`_  2022-02-08   ``Fixed changelog for January 2022 (delayed) provider's release (#21439)``
+`6c3a67d4fc <https://github.com/apache/airflow/commit/6c3a67d4fccafe4ab6cd9ec8c7bacf2677f17038>`_  2022-02-05   ``Add documentation for January 2021 providers release (#21257)``
+`602abe8394 <https://github.com/apache/airflow/commit/602abe8394fafe7de54df7e73af56de848cdf617>`_  2022-01-20   ``Remove ':type' lines now sphinx-autoapi supports typehints (#20951)``
+`03b08aad8c <https://github.com/apache/airflow/commit/03b08aad8c71204da7edc1202ff9928ff236366a>`_  2022-01-14   ``Fix Vault Hook default connection name (#20792)``
+`f77417eb0d <https://github.com/apache/airflow/commit/f77417eb0d3f12e4849d80645325c02a48829278>`_  2021-12-31   ``Fix K8S changelog to be PyPI-compatible (#20614)``
+`97496ba2b4 <https://github.com/apache/airflow/commit/97496ba2b41063fa24393c58c5c648a0cdb5a7f8>`_  2021-12-31   ``Update documentation for provider December 2021 release (#20523)``
+`2fb5e1d0ec <https://github.com/apache/airflow/commit/2fb5e1d0ec306839a3ff21d0bddbde1d022ee8c7>`_  2021-12-15   ``Fix cached_property MyPy declaration and related MyPy errors (#20226)``
+=================================================================================================  ===========  ==========================================================================
+
+2.1.1
+.....
+
+Latest change: 2021-09-30
+
+=================================================================================================  ===========  =================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  =================================================================
+`840ea3efb9 <https://github.com/apache/airflow/commit/840ea3efb9533837e9f36b75fa527a0fbafeb23a>`_  2021-09-30   ``Update documentation for September providers release (#18613)``
+`476ae0eb58 <https://github.com/apache/airflow/commit/476ae0eb588a5bfbc3d415a34cf4f0262f53888e>`_  2021-09-10   ``Fixing Vault AppRole authentication with CONN_URI (#18064)``
+=================================================================================================  ===========  =================================================================
+
+2.1.0
+.....
+
+Latest change: 2021-09-03
+
+=================================================================================================  ===========  ============================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ============================================================================
+`fd5d65751c <https://github.com/apache/airflow/commit/fd5d65751ca026d2b5f0ec1e4d9ce1b1e09e5b22>`_  2021-09-03   ``Update release notes for 3 extra providers released (#18018)``
+`16b47cecfb <https://github.com/apache/airflow/commit/16b47cecfb5cf88b0176a59589cbd77e0eaccfd3>`_  2021-09-01   ``Invalidate Vault cached prop when not authenticated (#17387)``
+`a29503e1ba <https://github.com/apache/airflow/commit/a29503e1baf7534c85ebf6685ba91003051c1cea>`_  2021-08-31   ``Fix instantiating Vault Secret Backend during configuration (#17935)``
+`0a68588479 <https://github.com/apache/airflow/commit/0a68588479e34cf175d744ea77b283d9d78ea71a>`_  2021-08-30   ``Add August 2021 Provider's documentation (#17890)``
+`be75dcd39c <https://github.com/apache/airflow/commit/be75dcd39cd10264048c86e74110365bd5daf8b7>`_  2021-08-23   ``Update description about the new ''connection-types'' provider meta-data``
+`6301faa388 <https://github.com/apache/airflow/commit/6301faa3888371ef361e704844f36d9bf768f731>`_  2021-08-23   ``Enable Connection creation from Vault parameters (#15013)``
+`76ed2a49c6 <https://github.com/apache/airflow/commit/76ed2a49c6cd285bf59706cf04f39a7444c382c9>`_  2021-08-19   ``Import Hooks lazily individually in providers manager (#17682)``
+`29aab6434f <https://github.com/apache/airflow/commit/29aab6434ffe0fb8c83b6fd6c9e44310966d496a>`_  2021-08-17   ``Adds secrets backend/logging/auth information to provider yaml (#17625)``
+`87f408b1e7 <https://github.com/apache/airflow/commit/87f408b1e78968580c760acb275ae5bb042161db>`_  2021-07-26   ``Prepares docs for Rc2 release of July providers (#17116)``
+`b916b75079 <https://github.com/apache/airflow/commit/b916b7507921129dc48d6add1bdc4b923b60c9b9>`_  2021-07-15   ``Prepare documentation for July release of providers. (#17015)``
+`866a601b76 <https://github.com/apache/airflow/commit/866a601b76e219b3c043e1dbbc8fb22300866351>`_  2021-06-28   ``Removes pylint from our toolchain (#16682)``
+=================================================================================================  ===========  ============================================================================
+
+2.0.0
+.....
+
+Latest change: 2021-06-18
+
+=================================================================================================  ===========  ==================================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ==================================================================================
+`bbc627a3da <https://github.com/apache/airflow/commit/bbc627a3dab17ba4cf920dd1a26dbed6f5cebfd1>`_  2021-06-18   ``Prepares documentation for rc2 release of Providers (#16501)``
+`cbf8001d76 <https://github.com/apache/airflow/commit/cbf8001d7630530773f623a786f9eb319783b33c>`_  2021-06-16   ``Synchronizes updated changelog after buggfix release (#16464)``
+`1fba5402bb <https://github.com/apache/airflow/commit/1fba5402bb14b3ffa6429fdc683121935f88472f>`_  2021-06-15   ``More documentation update for June providers release (#16405)``
+`70cfe01353 <https://github.com/apache/airflow/commit/70cfe0135373d1f0400e7d9b275ebb017429794b>`_  2021-06-12   ``Sanitize end of line character when loading token from a file (vault) (#16407)``
+`9c94b72d44 <https://github.com/apache/airflow/commit/9c94b72d440b18a9e42123d20d48b951712038f9>`_  2021-06-07   ``Updated documentation for June 2021 provider release (#16294)``
+=================================================================================================  ===========  ==================================================================================
+
+1.0.2
+.....
+
+Latest change: 2021-04-06
+
+=================================================================================================  ===========  =============================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  =============================================================================
+`042be2e4e0 <https://github.com/apache/airflow/commit/042be2e4e06b988f5ba2dc146f53774dabc8b76b>`_  2021-04-06   ``Updated documentation for provider packages before April release (#15236)``
+`b74f796c83 <https://github.com/apache/airflow/commit/b74f796c833283c820c81b20df1ba9f9cfa485c3>`_  2021-04-06   ``Fix deprecated warning hvac auth (#15216)``
+`68e4c4dcb0 <https://github.com/apache/airflow/commit/68e4c4dcb0416eb51a7011a3bb040f1e23d7bba8>`_  2021-03-20   ``Remove Backport Providers (#14886)``
+`e7bb17aeb8 <https://github.com/apache/airflow/commit/e7bb17aeb83b2218620c5320241b0c9f902d74ff>`_  2021-03-06   ``Use built-in 'cached_property' on Python 3.8 where possible (#14606)``
+=================================================================================================  ===========  =============================================================================
+
+1.0.1
+.....
+
+Latest change: 2021-02-04
+
+=================================================================================================  ===========  ========================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ========================================================
+`88bdcfa0df <https://github.com/apache/airflow/commit/88bdcfa0df5bcb4c489486e05826544b428c8f43>`_  2021-02-04   ``Prepare to release a new wave of providers. (#14013)``
+`ac2f72c98d <https://github.com/apache/airflow/commit/ac2f72c98dc0821b33721054588adbf2bb53bb0b>`_  2021-02-01   ``Implement provider versioning tools (#13767)``
+`3fd5ef3555 <https://github.com/apache/airflow/commit/3fd5ef355556cf0ad7896bb570bbe4b2eabbf46e>`_  2021-01-21   ``Add missing logos for integrations (#13717)``
+`295d66f914 <https://github.com/apache/airflow/commit/295d66f91446a69610576d040ba687b38f1c5d0a>`_  2020-12-30   ``Fix Grammar in PIP warning (#13380)``
+`6cf76d7ac0 <https://github.com/apache/airflow/commit/6cf76d7ac01270930de7f105fb26428763ee1d4e>`_  2020-12-18   ``Fix typo in pip upgrade command :( (#13148)``
+=================================================================================================  ===========  ========================================================
+
+1.0.0
+.....
+
+Latest change: 2020-12-09
+
+=================================================================================================  ===========  ==================================================================================
+Commit                                                                                             Committed    Subject
+=================================================================================================  ===========  ==================================================================================
+`32971a1a2d <https://github.com/apache/airflow/commit/32971a1a2de1db0b4f7442ed26facdf8d3b7a36f>`_  2020-12-09   ``Updates providers versions to 1.0.0 (#12955)``
+`b40dffa085 <https://github.com/apache/airflow/commit/b40dffa08547b610162f8cacfa75847f3c4ca364>`_  2020-12-08   ``Rename remaing modules to match AIP-21 (#12917)``
+`9b39f24780 <https://github.com/apache/airflow/commit/9b39f24780e85f859236672e9060b2fbeee81b36>`_  2020-12-08   ``Add support for dynamic connection form fields per provider (#12558)``
+`36a9b0f48b <https://github.com/apache/airflow/commit/36a9b0f48baf4a8ef8fc02a450a279948a8c0f02>`_  2020-11-20   ``Fix the default value for VaultBackend's config_path (#12518)``
+`c34ef853c8 <https://github.com/apache/airflow/commit/c34ef853c890e08f5468183c03dc8f3f3ce84af2>`_  2020-11-20   ``Separate out documentation building per provider  (#12444)``
+`0080354502 <https://github.com/apache/airflow/commit/00803545023b096b8db4fbd6eb473843096d7ce4>`_  2020-11-18   ``Update provider READMEs for 1.0.0b2 batch release (#12449)``
+`7ca0b6f121 <https://github.com/apache/airflow/commit/7ca0b6f121c9cec6e25de130f86a56d7c7fbe38c>`_  2020-11-18   ``Enable Markdownlint rule MD003/heading-style/header-style (#12427) (#12438)``
+`ae7cb4a1e2 <https://github.com/apache/airflow/commit/ae7cb4a1e2a96351f1976cf5832615e24863e05d>`_  2020-11-17   ``Update wrong commit hash in backport provider changes (#12390)``
+`6889a333cf <https://github.com/apache/airflow/commit/6889a333cff001727eb0a66e375544a28c9a5f03>`_  2020-11-15   ``Improvements for operators and hooks ref docs (#12366)``
+`7825e8f590 <https://github.com/apache/airflow/commit/7825e8f59034645ab3247229be83a3aa90baece1>`_  2020-11-13   ``Docs installation improvements (#12304)``
+`85a18e13d9 <https://github.com/apache/airflow/commit/85a18e13d9dec84275283ff69e34704b60d54a75>`_  2020-11-09   ``Point at pypi project pages for cross-dependency of provider packages (#12212)``
+`59eb5de78c <https://github.com/apache/airflow/commit/59eb5de78c70ee9c7ae6e4cba5c7a2babb8103ca>`_  2020-11-09   ``Update provider READMEs for up-coming 1.0.0beta1 releases (#12206)``
+`b2a28d1590 <https://github.com/apache/airflow/commit/b2a28d1590410630d66966aa1f2b2a049a8c3b32>`_  2020-11-09   ``Moves provider packages scripts to dev (#12082)``
+`4e8f9cc8d0 <https://github.com/apache/airflow/commit/4e8f9cc8d02b29c325b8a5a76b4837671bdf5f68>`_  2020-11-03   ``Enable Black - Python Auto Formmatter (#9550)``
+`dd2442b1e6 <https://github.com/apache/airflow/commit/dd2442b1e66d4725e7193e0cab0548a4d8c71fbd>`_  2020-11-02   ``Vault with optional Variables or Connections (#11736)``
+`5a439e84eb <https://github.com/apache/airflow/commit/5a439e84eb6c0544dc6c3d6a9f4ceeb2172cd5d0>`_  2020-10-26   ``Prepare providers release 0.0.2a1 (#11855)``
+`872b1566a1 <https://github.com/apache/airflow/commit/872b1566a11cb73297e657ff325161721b296574>`_  2020-10-25   ``Generated backport providers readmes/setup for 2020.10.29 (#11826)``
+`349b0811c3 <https://github.com/apache/airflow/commit/349b0811c3022605426ba57d30936240a7c2848a>`_  2020-10-20   ``Add D200 pydocstyle check (#11688)``
+`16e7129719 <https://github.com/apache/airflow/commit/16e7129719f1c0940aef2a93bed81368e997a746>`_  2020-10-13   ``Added support for provider packages for Airflow 2.0 (#11487)``
+`0a0e1af800 <https://github.com/apache/airflow/commit/0a0e1af80038ef89974c3c8444461fe867945daa>`_  2020-10-03   ``Fix Broken Markdown links in Providers README TOC (#11249)``
+`ca4238eb4d <https://github.com/apache/airflow/commit/ca4238eb4d9a2aef70eb641343f59ee706d27d13>`_  2020-10-02   ``Fixed month in backport packages to October (#11242)``
+`5220e4c384 <https://github.com/apache/airflow/commit/5220e4c3848a2d2c81c266ef939709df9ce581c5>`_  2020-10-02   ``Prepare Backport release 2020.09.07 (#11238)``
+`9549274d11 <https://github.com/apache/airflow/commit/9549274d110f689a0bd709db829a4d69e274eed9>`_  2020-09-09   ``Upgrade black to 20.8b1 (#10818)``
+`3867f76625 <https://github.com/apache/airflow/commit/3867f7662559761864ec4e7be26b776c64c2f199>`_  2020-08-28   ``Update Google Cloud branding (#10615)``
+`fdd9b6f65b <https://github.com/apache/airflow/commit/fdd9b6f65b608c516b8a062b058972d9a45ec9e3>`_  2020-08-25   ``Enable Black on Providers Packages (#10543)``
+`3696c34c28 <https://github.com/apache/airflow/commit/3696c34c28c6bc7b442deab999d9ecba24ed0e34>`_  2020-08-24   ``Fix typo in the word "release" (#10528)``
+`2f2d8dbfaf <https://github.com/apache/airflow/commit/2f2d8dbfafefb4be3dd80f22f31c649c8498f148>`_  2020-08-25   ``Remove all "noinspection" comments native to IntelliJ (#10525)``
+`ee7ca128a1 <https://github.com/apache/airflow/commit/ee7ca128a17937313566f2badb6cc569c614db94>`_  2020-08-22   ``Fix broken Markdown refernces in Providers README (#10483)``
+`2f31b3060e <https://github.com/apache/airflow/commit/2f31b3060ed8274d5d1b1db7349ce607640b9199>`_  2020-07-08   ``Get Airflow configs with sensitive data from Secret Backends (#9645)``
+`44d4ae809c <https://github.com/apache/airflow/commit/44d4ae809c1e3784ff95b6a5e95113c3412e56b3>`_  2020-07-06   ``Upgrade to latest pre-commit checks (#9686)``
+`a99aaeb496 <https://github.com/apache/airflow/commit/a99aaeb49672e913d5ff79606237f6f3614fc8f5>`_  2020-07-03   ``Allow setting Hashicorp Vault token from File (#9644)``
+`d0e7db4024 <https://github.com/apache/airflow/commit/d0e7db4024806af35e3c9a2cae460fdeedd4d2ec>`_  2020-06-19   ``Fixed release number for fresh release (#9408)``
+`12af6a0800 <https://github.com/apache/airflow/commit/12af6a08009b8776e00d8a0aab92363eb8c4e8b1>`_  2020-06-19   ``Final cleanup for 2020.6.23rc1 release preparation (#9404)``
+`df693e0e31 <https://github.com/apache/airflow/commit/df693e0e3138f6601c4776cd529d8cb7bcde2f90>`_  2020-06-19   ``Add more authentication options for HashiCorp Vault classes (#8974)``
+`c7e5bce57f <https://github.com/apache/airflow/commit/c7e5bce57fe7f51cefce4f8a41ce408ac5675d13>`_  2020-06-19   ``Prepare backport release candidate for 2020.6.23rc1 (#9370)``
+`d47e070a79 <https://github.com/apache/airflow/commit/d47e070a79b574cca043ca9c06f91d47eecb3040>`_  2020-06-17   ``Add HashiCorp Vault Hook (split-out from Vault secret backend) (#9333)``
+`f6bd817a3a <https://github.com/apache/airflow/commit/f6bd817a3aac0a16430fc2e3d59c1f17a69a15ac>`_  2020-06-16   ``Introduce 'transfers' packages (#9320)``
+`0b0e4f7a4c <https://github.com/apache/airflow/commit/0b0e4f7a4cceff3efe15161fb40b984782760a34>`_  2020-05-26   ``Preparing for RC3 relase of backports (#9026)``
+`00642a46d0 <https://github.com/apache/airflow/commit/00642a46d019870c4decb3d0e47c01d6a25cb88c>`_  2020-05-26   ``Fixed name of 20 remaining wrongly named operators. (#8994)``
+`375d1ca229 <https://github.com/apache/airflow/commit/375d1ca229464617780623c61c6e8a1bf570c87f>`_  2020-05-19   ``Release candidate 2 for backport packages 2020.05.20 (#8898)``
+`12c5e5d8ae <https://github.com/apache/airflow/commit/12c5e5d8ae25fa633efe63ccf4db389e2b796d79>`_  2020-05-17   ``Prepare release candidate for backport packages (#8891)``
+`f3521fb0e3 <https://github.com/apache/airflow/commit/f3521fb0e36733d8bd356123e56a453fd37a6dca>`_  2020-05-16   ``Regenerate readme files for backport package release (#8886)``
+`92585ca4cb <https://github.com/apache/airflow/commit/92585ca4cb375ac879f4ab331b3a063106eb7b92>`_  2020-05-15   ``Added automated release notes generation for backport operators (#8807)``
+`d8cb0b5ddb <https://github.com/apache/airflow/commit/d8cb0b5ddb02d194742e374d9ac90dd8231f6e80>`_  2020-05-04   ``Support k8s auth method in Vault Secrets provider (#8640)``
+`87969a350d <https://github.com/apache/airflow/commit/87969a350ddd41e9e77776af6d780b31e363eaca>`_  2020-04-09   ``[AIRFLOW-6515] Change Log Levels from Info/Warn to Error (#8170)``
+`c1c88abfed <https://github.com/apache/airflow/commit/c1c88abfede7a36c3b1d1b511fbc6c03af46d363>`_  2020-03-28   ``Get Airflow Variables from Hashicorp Vault (#7944)``
+`eb4af4f944 <https://github.com/apache/airflow/commit/eb4af4f944c77e67e167bbb6b0a2aaf075a95b50>`_  2020-03-28   ``Make BaseSecretsBackend.build_path generic (#7948)``
+`686d7d50bd <https://github.com/apache/airflow/commit/686d7d50bd21622724d6818021355bc6885fd3de>`_  2020-03-25   ``Standardize SecretBackend class names (#7846)``
+`eef87b9953 <https://github.com/apache/airflow/commit/eef87b9953347a65421f315a07dbef37ded9df66>`_  2020-03-23   ``[AIRFLOW-7105] Unify Secrets Backend method interfaces (#7830)``
+`cdf1809fce <https://github.com/apache/airflow/commit/cdf1809fce0e59c8379a799f1738d8d813abbf51>`_  2020-03-23   ``[AIRFLOW-7104] Add Secret backend for GCP Secrets Manager (#7795)``
+`a44beaf5bd <https://github.com/apache/airflow/commit/a44beaf5bddae2a8de0429af45be5ff78a7d4d4e>`_  2020-03-19   ``[AIRFLOW-7076] Add support for HashiCorp Vault as Secrets Backend (#7741)``
+=================================================================================================  ===========  ==================================================================================
diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/secrets-backends/hashicorp-vault.rst.txt b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/secrets-backends/hashicorp-vault.rst.txt
new file mode 100644
index 0000000000..f94ae7edcb
--- /dev/null
+++ b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/_sources/secrets-backends/hashicorp-vault.rst.txt
@@ -0,0 +1,216 @@
+ .. Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+ ..   http://www.apache.org/licenses/LICENSE-2.0
+
+ .. Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+.. _hashicorp_vault_secrets:
+
+Hashicorp Vault Secrets Backend
+^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
+
+To enable Hashicorp vault to retrieve Airflow connection/variable, specify :py:class:`~airflow.providers.hashicorp.secrets.vault.VaultBackend`
+as the ``backend`` in  ``[secrets]`` section of ``airflow.cfg``.
+
+Here is a sample configuration:
+
+.. code-block:: ini
+
+    [secrets]
+    backend = airflow.providers.hashicorp.secrets.vault.VaultBackend
+    backend_kwargs = {"connections_path": "connections", "variables_path": "variables", "mount_point": "airflow", "url": "http://127.0.0.1:8200"}
+
+The default KV version engine is ``2``, pass ``kv_engine_version: 1`` in ``backend_kwargs`` if you use
+KV Secrets Engine Version ``1``.
+
+You can also set and pass values to Vault client by setting environment variables. All the
+environment variables listed at https://www.vaultproject.io/docs/commands/#environment-variables are supported.
+
+Hence, if you set ``VAULT_ADDR`` environment variable like below, you do not need to pass ``url``
+key to ``backend_kwargs``:
+
+.. code-block:: bash
+
+    export VAULT_ADDR="http://127.0.0.1:8200"
+
+Set up a Vault mount point
+""""""""""""""""""""""""""
+
+You can make a ``mount_point`` for ``airflow`` as follows:
+
+.. code-block:: bash
+
+    vault secrets enable -path=airflow -version=2 kv
+
+Optional lookup
+"""""""""""""""
+
+Optionally connections, variables, or config may be looked up exclusive of each other or in any combination.
+This will prevent requests being sent to Vault for the excluded type.
+
+If you want to look up some and not others in Vault you may do so by setting the relevant ``*_path`` parameter of the ones to be excluded as ``null``.
+
+For example, if you want to set parameter ``connections_path`` to ``"airflow-connections"`` and not look up variables, your configuration file should look like this:
+
+.. code-block:: ini
+
+    [secrets]
+    backend = airflow.providers.hashicorp.secrets.vault.VaultBackend
+    backend_kwargs = {"connections_path": "airflow-connections", "variables_path": null, "mount_point": "airflow", "url": "http://127.0.0.1:8200"}
+
+Storing and Retrieving Connections using connection URI representation
+""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""
+
+If you have set ``connections_path`` as ``connections`` and ``mount_point`` as ``airflow``, then for a connection id of
+``smtp_default``, you would want to store your secret as:
+
+.. code-block:: bash
+
+    vault kv put airflow/connections/smtp_default conn_uri=smtps://user:host@relay.example.com:465
+
+Note that the ``Key`` is ``conn_uri``, ``Value`` is ``smtps://user:host@relay.example.com:465`` and
+``mount_point`` is ``airflow``.
+
+Verify that you can get the secret from ``vault``:
+
+.. code-block:: console
+
+    ❯ vault kv get airflow/connections/smtp_default
+    ====== Metadata ======
+    Key              Value
+    ---              -----
+    created_time     2020-03-19T19:17:51.281721Z
+    deletion_time    n/a
+    destroyed        false
+    version          1
+
+    ====== Data ======
+    Key         Value
+    ---         -----
+    conn_uri    smtps://user:host@relay.example.com:465
+
+The value of the Vault key must be the :ref:`connection URI representation <generating_connection_uri>`
+of the connection object to get connection.
+
+Storing and Retrieving Connections using Connection class representation
+""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""""
+
+If you have set ``connections_path`` as ``connections`` and ``mount_point`` as ``airflow``, then for a connection id of
+``smtp_default``, you would want to store your secret as:
+
+.. code-block:: bash
+
+    vault kv put airflow/connections/smtp_default conn_type=smtps login=user password=host host=relay.example.com port=465
+
+Note that the ``Keys`` are parameters of the ``Connection`` class and the ``Value`` their argument.
+
+Verify that you can get the secret from ``vault``:
+
+.. code-block:: console
+
+    ❯ vault kv get airflow/connections/smtp_default
+    ====== Metadata ======
+    Key              Value
+    ---              -----
+    created_time     2020-03-19T19:17:51.281721Z
+    deletion_time    n/a
+    destroyed        false
+    version          1
+
+    ====== Data ======
+    Key         Value
+    ---         -----
+    conn_type   smtps
+    login       user
+    password    host
+    host        relay.example.com
+    port        465
+
+Storing and Retrieving Variables
+""""""""""""""""""""""""""""""""
+
+If you have set ``variables_path`` as ``variables`` and ``mount_point`` as ``airflow``, then for a variable with
+``hello`` as key, you would want to store your secret as:
+
+.. code-block:: bash
+
+    vault kv put airflow/variables/hello value=world
+
+Verify that you can get the secret from ``vault``:
+
+.. code-block:: console
+
+    ❯ vault kv get airflow/variables/hello
+    ====== Metadata ======
+    Key              Value
+    ---              -----
+    created_time     2020-03-28T02:10:54.301784Z
+    deletion_time    n/a
+    destroyed        false
+    version          1
+
+    ==== Data ====
+    Key      Value
+    ---      -----
+    value    world
+
+Note that the secret ``Key`` is ``value``, and secret ``Value`` is ``world`` and
+``mount_point`` is ``airflow``.
+
+Storing and Retrieving Config
+""""""""""""""""""""""""""""""""
+
+If you have set ``config_path`` as ``config`` and ``mount_point`` as ``airflow``, then for config ``sql_alchemy_conn_secret`` with
+``sql_alchemy_conn_value`` as value, you would want to store your secret as:
+
+.. code-block:: bash
+
+    vault kv put airflow/config/sql_alchemy_conn_value value=postgres://user:pass@host:5432/db?ssl_mode=disable
+
+Verify that you can get the secret from ``vault``:
+
+.. code-block:: console
+
+    ❯ vault kv get airflow/config/sql_alchemy_conn_value
+    ====== Metadata ======
+    Key              Value
+    ---              -----
+    created_time     2020-03-28T02:10:54.301784Z
+    deletion_time    n/a
+    destroyed        false
+    version          1
+
+    ==== Data ====
+    Key      Value
+    ---      -----
+    value    postgres://user:pass@host:5432/db?ssl_mode=disable
+
+Then you can use above secret for ``sql_alchemy_conn_secret`` in your configuration file.
+
+.. code-block:: ini
+
+    [core]
+     sql_alchemy_conn_secret: "sql_alchemy_conn_value"
+
+Note that the secret ``Key`` is ``value``, and secret ``Value`` is ``postgres://user:pass@host:5432/db?ssl_mode=disable`` and
+``mount_point`` is ``airflow``.
+
+## For Vault running with self signed certificates
+Add "verify": "absolute path to ca-certificate file"
+
+.. code-block:: ini
+
+    [secrets]
+    backend = airflow.providers.hashicorp.secrets.vault.VaultBackend
+    backend_kwargs = {"connections_path": "airflow-connections", "variables_path": null, "mount_point": "airflow", "url": "http://127.0.0.1:8200", "verify": "/etc/ssl/certs/ca-certificates"}
diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/objects.inv b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/objects.inv
new file mode 100644
index 0000000000..3866e9d60b
Binary files /dev/null and b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/objects.inv differ
diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/searchindex.js b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/searchindex.js
new file mode 100644
index 0000000000..adf5d92b74
--- /dev/null
+++ b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/searchindex.js
@@ -0,0 +1 @@
+Search.setIndex({"docnames": ["_api/airflow/providers/hashicorp/hooks/index", "_api/airflow/providers/hashicorp/hooks/vault/index", "_api/airflow/providers/hashicorp/index", "_api/airflow/providers/hashicorp/secrets/index", "_api/airflow/providers/hashicorp/secrets/vault/index", "commits", "index", "installing-providers-from-sources", "secrets-backends/hashicorp-vault"], "filenames": ["_api/airflow/providers/hashicorp/hooks/index.rst", "_api/airflow/providers/hashicorp/hooks/vault/index. [...]
\ No newline at end of file
diff --git a/docs-archive/apache-airflow-providers-hashicorp/3.3.0/secrets-backends/index.html b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/secrets-backends/index.html
new file mode 100644
index 0000000000..ae7ce5c306
--- /dev/null
+++ b/docs-archive/apache-airflow-providers-hashicorp/3.3.0/secrets-backends/index.html
@@ -0,0 +1 @@
+<html><head><meta http-equiv="refresh" content="0; url=../secrets-backends/hashicorp-vault-secrets-backend.html"/></head></html>
\ No newline at end of file
diff --git a/docs-archive/apache-airflow-providers-hashicorp/stable.txt b/docs-archive/apache-airflow-providers-hashicorp/stable.txt
index 944880fa15..0fa4ae4890 100644
--- a/docs-archive/apache-airflow-providers-hashicorp/stable.txt
+++ b/docs-archive/apache-airflow-providers-hashicorp/stable.txt
@@ -1 +1 @@
-3.2.0
+3.3.0
\ No newline at end of file