You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by GitBox <gi...@apache.org> on 2018/08/15 05:09:28 UTC

[GitHub] bolkedebruin closed pull request #3750: [AIRFLOW-XXX] Clean up installation extra packages table

bolkedebruin closed pull request #3750: [AIRFLOW-XXX] Clean up installation extra packages table
URL: https://github.com/apache/incubator-airflow/pull/3750
 
 
   

This is a PR merged from a forked repository.
As GitHub hides the original diff on merge, it is displayed below for
the sake of provenance:

As this is a foreign pull request (from a fork), the diff is supplied
below (as it won't show otherwise due to GitHub magic):

diff --git a/docs/installation.rst b/docs/installation.rst
index e012b288a8..4beef47d3a 100644
--- a/docs/installation.rst
+++ b/docs/installation.rst
@@ -41,68 +41,67 @@ Here's the list of the subpackages and what they enable:
 +---------------+----------------------------------------------+-------------------------------------------------+
 | subpackage    | install command                              | enables                                         |
 +===============+==============================================+=================================================+
-|  all          | ``pip install apache-airflow[all]``          | All Airflow features known to man               |
+| all           | ``pip install apache-airflow[all]``          | All Airflow features known to man               |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  all_dbs      | ``pip install apache-airflow[all_dbs]``      | All databases integrations                      |
+| all_dbs       | ``pip install apache-airflow[all_dbs]``      | All databases integrations                      |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  async        | ``pip install apache-airflow[async]``        | Async worker classes for gunicorn               |
+| async         | ``pip install apache-airflow[async]``        | Async worker classes for Gunicorn               |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  devel        | ``pip install apache-airflow[devel]``        | Minimum dev tools requirements                  |
+| celery        | ``pip install apache-airflow[celery]``       | CeleryExecutor                                  |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  devel_hadoop | ``pip install apache-airflow[devel_hadoop]`` | Airflow + dependencies on the Hadoop stack      |
+| cloudant      | ``pip install apache-airflow[cloudant]``     | Cloudant hook                                   |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  celery       | ``pip install apache-airflow[celery]``       | CeleryExecutor                                  |
+| crypto        | ``pip install apache-airflow[crypto]``       | Encrypt connection passwords in metadata db     |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  crypto       | ``pip install apache-airflow[crypto]``       | Encrypt connection passwords in metadata db     |
+| devel         | ``pip install apache-airflow[devel]``        | Minimum dev tools requirements                  |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  druid        | ``pip install apache-airflow[druid]``        | Druid.io related operators & hooks              |
+| devel_hadoop  | ``pip install apache-airflow[devel_hadoop]`` | Airflow + dependencies on the Hadoop stack      |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  gcp_api      | ``pip install apache-airflow[gcp_api]``      | Google Cloud Platform hooks and operators       |
+| druid         | ``pip install apache-airflow[druid]``        | Druid related operators & hooks                 |
++---------------+----------------------------------------------+-------------------------------------------------+
+| gcp_api       | ``pip install apache-airflow[gcp_api]``      | Google Cloud Platform hooks and operators       |
 |               |                                              | (using ``google-api-python-client``)            |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  jdbc         | ``pip install apache-airflow[jdbc]``         | JDBC hooks and operators                        |
+| hdfs          | ``pip install apache-airflow[hdfs]``         | HDFS hooks and operators                        |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  hdfs         | ``pip install apache-airflow[hdfs]``         | HDFS hooks and operators                        |
+| hive          | ``pip install apache-airflow[hive]``         | All Hive related operators                      |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  hive         | ``pip install apache-airflow[hive]``         | All Hive related operators                      |
+| jdbc          | ``pip install apache-airflow[jdbc]``         | JDBC hooks and operators                        |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  kerberos     | ``pip install apache-airflow[kerberos]``     | kerberos integration for kerberized hadoop      |
+| kerbero s     | ``pip install apache-airflow[kerberos]``     | Kerberos integration for Kerberized Hadoop      |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  ldap         | ``pip install apache-airflow[ldap]``         | ldap authentication for users                   |
+| ldap          | ``pip install apache-airflow[ldap]``         | LDAP authentication for users                   |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  mssql        | ``pip install apache-airflow[mssql]``        | Microsoft SQL operators and hook,               |
+| mssql         | ``pip install apache-airflow[mssql]``        | Microsoft SQL Server operators and hook,        |
 |               |                                              | support as an Airflow backend                   |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  mysql        | ``pip install apache-airflow[mysql]``        | MySQL operators and hook, support as            |
-|               |                                              | an Airflow backend. The version of MySQL server |
-|               |                                              | has to be 5.6.4+. The exact version upper bound |
-|               |                                              | depends on version of ``mysqlclient`` package.  |
-|               |                                              | For example, ``mysqlclient`` 1.3.12 can only be |
+| mysql         | ``pip install apache-airflow[mysql]``        | MySQL operators and hook, support as an Airflow |
+|               |                                              | backend. The version of MySQL server has to be  |
+|               |                                              | 5.6.4+. The exact version upper bound depends   |
+|               |                                              | on version of ``mysqlclient`` package. For      |
+|               |                                              | example, ``mysqlclient`` 1.3.12 can only be     |
 |               |                                              | used with MySQL server 5.6.4 through 5.7.       |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  password     | ``pip install apache-airflow[password]``     | Password Authentication for users               |
-+---------------+----------------------------------------------+-------------------------------------------------+
-|  postgres     | ``pip install apache-airflow[postgres]``     | Postgres operators and hook, support            |
-|               |                                              | as an Airflow backend                           |
+| password      | ``pip install apache-airflow[password]``     | Password authentication for users               |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  qds          | ``pip install apache-airflow[qds]``          | Enable QDS (qubole data services) support       |
+| postgres      | ``pip install apache-airflow[postgres]``     | PostgreSQL operators and hook, support as an    |
+|               |                                              | Airflow backend                                 |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  rabbitmq     | ``pip install apache-airflow[rabbitmq]``     | Rabbitmq support as a Celery backend            |
+| qds           | ``pip install apache-airflow[qds]``          | Enable QDS (Qubole Data Service) support        |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  s3           | ``pip install apache-airflow[s3]``           | ``S3KeySensor``, ``S3PrefixSensor``             |
+| rabbitmq      | ``pip install apache-airflow[rabbitmq]``     | RabbitMQ support as a Celery backend            |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  samba        | ``pip install apache-airflow[samba]``        | ``Hive2SambaOperator``                          |
+| redis         | ``pip install apache-airflow[redis]``        | Redis hooks and sensors                         |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  slack        | ``pip install apache-airflow[slack]``        | ``SlackAPIPostOperator``                        |
+| s3            | ``pip install apache-airflow[s3]``           | ``S3KeySensor``, ``S3PrefixSensor``             |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  ssh          | ``pip install apache-airflow[ssh]``          | SSh hooks and Operator                          |
+| samba         | ``pip install apache-airflow[samba]``        | ``Hive2SambaOperator``                          |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  vertica      | ``pip install apache-airflow[vertica]``      | Vertica hook                                    |
-|               |                                              | support as an Airflow backend                   |
+| slack         | ``pip install apache-airflow[slack]``        | ``SlackAPIPostOperator``                        |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  cloudant     | ``pip install apache-airflow[cloudant]``     | Cloudant hook                                   |
+| ssh           | ``pip install apache-airflow[ssh]``          | SSH hooks and Operator                          |
 +---------------+----------------------------------------------+-------------------------------------------------+
-|  redis        | ``pip install apache-airflow[redis]``        | Redis hooks and sensors                         |
+| vertica       | ``pip install apache-airflow[vertica]``      | Vertica hook support as an Airflow backend      |
 +---------------+----------------------------------------------+-------------------------------------------------+
 
 Initiating Airflow Database


 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services