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 2020/08/24 16:53:49 UTC

[GitHub] [airflow] xu-xiang opened a new issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

xu-xiang opened a new issue #10516:
URL: https://github.com/apache/airflow/issues/10516


   <!--
   
   Welcome to Apache Airflow!  For a smooth issue process, try to answer the following questions.
   Don't worry if they're not all applicable; just try to include what you can :-)
   
   If you need to include code snippets or logs, please put them in fenced code
   blocks.  If they're super-long, please use the details tag like
   <details><summary>super-long log</summary> lots of stuff </details>
   
   Please delete these comment blocks before submitting the issue.
   
   -->
   
   <!--
   
   IMPORTANT!!!
   
   PLEASE CHECK "SIMILAR TO X EXISTING ISSUES" OPTION IF VISIBLE
   NEXT TO "SUBMIT NEW ISSUE" BUTTON!!!
   
   PLEASE CHECK IF THIS ISSUE HAS BEEN REPORTED PREVIOUSLY USING SEARCH!!!
   
   Please complete the next sections or the issue will be closed.
   This questions are the first thing we need to know to understand the context.
   
   -->
   
   **Apache Airflow version**:
   ```
   apache-airflow==2.0.0.dev0
   master
   ```
   
   **Kubernetes version (if you are using kubernetes)** (use `kubectl version`):
   
   **Environment**:
   
   - **Cloud provider or hardware configuration**:
   - **OS** (e.g. from /etc/os-release):
   Mac OS 10.15.3
   - **Kernel** (e.g. `uname -a`):
   - **Install tools**:
   - **Others**:
   
   **What happened**:
   Install Airflow :
   ```
   (airflowenv) ➜ airflow git:(master) ✗ python3.8 setup.py install
   
   
   
   
   
   
   running install
   running bdist_egg
   running egg_info
   writing apache_airflow.egg-info/PKG-INFO
   writing dependency_links to apache_airflow.egg-info/dependency_links.txt
   writing entry points to apache_airflow.egg-info/entry_points.txt
   writing requirements to apache_airflow.egg-info/requires.txt
   writing top-level names to apache_airflow.egg-info/top_level.txt
   reading manifest file 'apache_airflow.egg-info/SOURCES.txt'
   reading manifest template 'MANIFEST.in'
   warning: no previously-included files matching '__pycache__' found anywhere in distribution
   warning: no files found matching 'airflow/providers/cncf/kubernetes/example_dags/example_spark_kubernetes_operator_spark_pi.yaml'
   writing manifest file 'apache_airflow.egg-info/SOURCES.txt'
   installing library code to build/bdist.macosx-10.9-x86_64/egg
   running install_lib
   running build_py
   copying kubernetes_tests/test_kubernetes_pod_operator.py -> build/lib/kubernetes_tests
   copying airflow/settings.py -> build/lib/airflow
   copying airflow/models/dagrun.py -> build/lib/airflow/models
   copying airflow/models/baseoperator.py -> build/lib/airflow/models
   copying airflow/jobs/scheduler_job.py -> build/lib/airflow/jobs
   ......
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/extensions/init_views.py to init_views.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/widgets.py to widgets.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/forms.py to forms.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/utils.py to utils.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/gunicorn_config.py to gunicorn_config.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/app.py to app.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/api/experimental/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/api/experimental/endpoints.py to endpoints.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/api/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/views.py to views.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/www/decorators.py to decorators.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/dependencies_states.py to dependencies_states.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/dep_context.py to dep_context.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/dependencies_deps.py to dependencies_deps.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/prev_dagrun_dep.py to prev_dagrun_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/task_concurrency_dep.py to task_concurrency_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/dag_unpaused_dep.py to dag_unpaused_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/exec_date_after_start_date_dep.py to exec_date_after_start_date_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/dagrun_exists_dep.py to dagrun_exists_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/runnable_exec_date_dep.py to runnable_exec_date_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/dagrun_id_dep.py to dagrun_id_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/base_ti_dep.py to base_ti_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/pool_slots_available_dep.py to pool_slots_available_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/trigger_rule_dep.py to trigger_rule_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/not_previously_skipped_dep.py to not_previously_skipped_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/task_not_running_dep.py to task_not_running_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/not_in_retry_period_dep.py to not_in_retry_period_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/dag_ti_slots_available_dep.py to dag_ti_slots_available_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/valid_state_dep.py to valid_state_dep.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/ti_deps/deps/ready_to_reschedule.py to ready_to_reschedule.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/macros/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/macros/hive.py to hive.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_latest_only.py to example_latest_only.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_complex.py to example_complex.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_python_operator.py to example_python_operator.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/test_utils.py to test_utils.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_external_task_marker_dag.py to example_external_task_marker_dag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_bash_operator.py to example_bash_operator.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_short_circuit_operator.py to example_short_circuit_operator.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_branch_operator.py to example_branch_operator.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/tutorial.py to tutorial.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_kubernetes_executor_config.py to example_kubernetes_executor_config.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_passing_params_via_test_command.py to example_passing_params_via_test_command.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_latest_only_with_trigger.py to example_latest_only_with_trigger.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/subdags/subdag.py to subdag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/subdags/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_xcom.py to example_xcom.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_xcomargs.py to example_xcomargs.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/libs/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/libs/helper.py to helper.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_skip_dag.py to example_skip_dag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_trigger_target_dag.py to example_trigger_target_dag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_kubernetes_executor.py to example_kubernetes_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_branch_python_dop_operator_3.py to example_branch_python_dop_operator_3.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_nested_branch_dag.py to example_nested_branch_dag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_subdag_operator.py to example_subdag_operator.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/example_dags/example_trigger_controller_dag.py to example_trigger_controller_dag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/celery_executor.py to celery_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/dask_executor.py to dask_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/executor_loader.py to executor_loader.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/kubernetes_executor.py to kubernetes_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/sequential_executor.py to sequential_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/local_executor.py to local_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/base_executor.py to base_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/executors/debug_executor.py to debug_executor.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/lineage/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/lineage/entities.py to entities.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/mypy/plugin/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/mypy/plugin/decorators.py to decorators.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/mypy/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/druid_hook.py to druid_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/base_hook.py to base_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/http_hook.py to http_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/presto_hook.py to presto_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/dbapi_hook.py to dbapi_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/slack_hook.py to slack_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/samba_hook.py to samba_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/hive_hooks.py to hive_hooks.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/filesystem.py to filesystem.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/oracle_hook.py to oracle_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/jdbc_hook.py to jdbc_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/mysql_hook.py to mysql_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/docker_hook.py to docker_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/postgres_hook.py to postgres_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/webhdfs_hook.py to webhdfs_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/pig_hook.py to pig_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/zendesk_hook.py to zendesk_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/S3_hook.py to S3_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/hdfs_hook.py to hdfs_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/mssql_hook.py to mssql_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/hooks/sqlite_hook.py to sqlite_hook.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/stats.py to stats.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/task/task_runner/standard_task_runner.py to standard_task_runner.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/task/task_runner/base_task_runner.py to base_task_runner.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/task/task_runner/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/task/task_runner/cgroup_task_runner.py to cgroup_task_runner.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/task/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/settings.py to settings.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/auth/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/auth/backend/kerberos_auth.py to kerberos_auth.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/auth/backend/deny_all.py to deny_all.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/auth/backend/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/auth/backend/default.py to default.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/auth/backend/basic_auth.py to basic_auth.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/mark_tasks.py to mark_tasks.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/get_dag_run_state.py to get_dag_run_state.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/trigger_dag.py to trigger_dag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/get_lineage.py to get_lineage.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/get_dag_runs.py to get_dag_runs.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/get_task.py to get_task.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/get_task_instance.py to get_task_instance.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/pool.py to pool.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/delete_dag.py to delete_dag.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/experimental/get_code.py to get_code.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/common/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/client/json_client.py to json_client.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/client/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/client/local_client.py to local_client.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/api/client/api_client.py to api_client.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/exceptions.py to exceptions.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/jobs/local_task_job.py to local_task_job.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/jobs/scheduler_job.py to scheduler_job.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/jobs/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/jobs/backfill_job.py to backfill_job.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/jobs/base_job.py to base_job.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/sentry.py to sentry.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/refresh_config.py to refresh_config.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/worker_configuration.py to worker_configuration.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/pod_generator.py to pod_generator.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/k8s_model.py to k8s_model.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/volume_mount.py to volume_mount.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/pod.py to pod.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/__init__.py to __init__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/kube_client.py to kube_client.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/volume.py to volume.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/secret.py to secret.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/pod_runtime_info_env.py to pod_runtime_info_env.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/kubernetes/pod_launcher.py to pod_launcher.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/__main__.py to __main__.cpython-38.pyc
   byte-compiling build/bdist.macosx-10.9-x86_64/egg/airflow/decorators.py to decorators.cpython-38.pyc
   creating build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   copying apache_airflow.egg-info/PKG-INFO -> build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   copying apache_airflow.egg-info/SOURCES.txt -> build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   copying apache_airflow.egg-info/dependency_links.txt -> build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   copying apache_airflow.egg-info/entry_points.txt -> build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   copying apache_airflow.egg-info/not-zip-safe -> build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   copying apache_airflow.egg-info/requires.txt -> build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   copying apache_airflow.egg-info/top_level.txt -> build/bdist.macosx-10.9-x86_64/egg/EGG-INFO
   creating 'dist/apache_airflow-2.0.0.dev0-py3.8.egg' and adding 'build/bdist.macosx-10.9-x86_64/egg' to it
   removing 'build/bdist.macosx-10.9-x86_64/egg' (and everything under it)
   Processing apache_airflow-2.0.0.dev0-py3.8.egg
   creating /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages/apache_airflow-2.0.0.dev0-py3.8.egg
   Extracting apache_airflow-2.0.0.dev0-py3.8.egg to /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Adding apache-airflow 2.0.0.dev0 to easy-install.pth file
   Installing airflow script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Installed /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages/apache_airflow-2.0.0.dev0-py3.8.egg
   Processing dependencies for apache-airflow==2.0.0.dev0
   Searching for Werkzeug==0.16.1
   Best match: Werkzeug 0.16.1
   Adding Werkzeug 0.16.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for unicodecsv==0.14.1
   Best match: unicodecsv 0.14.1
   Adding unicodecsv 0.14.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for tzlocal==1.5.1
   Best match: tzlocal 1.5.1
   Adding tzlocal 1.5.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for thrift==0.13.0
   Best match: thrift 0.13.0
   Adding thrift 0.13.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for tenacity==4.12.0
   Best match: tenacity 4.12.0
   Adding tenacity 4.12.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for tabulate==0.8.7
   Best match: tabulate 0.8.7
   Adding tabulate 0.8.7 to easy-install.pth file
   Installing tabulate script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for SQLAlchemy-JSONField==0.9.0
   Best match: SQLAlchemy-JSONField 0.9.0
   Adding SQLAlchemy-JSONField 0.9.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for SQLAlchemy==1.3.18
   Best match: SQLAlchemy 1.3.18
   Adding SQLAlchemy 1.3.18 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for setproctitle==1.1.10
   Best match: setproctitle 1.1.10
   Adding setproctitle 1.1.10 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for requests==2.24.0
   Best match: requests 2.24.0
   Adding requests 2.24.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for python-slugify==4.0.1
   Best match: python-slugify 4.0.1
   Adding python-slugify 4.0.1 to easy-install.pth file
   Installing slugify script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for python-nvd3==0.15.0
   Best match: python-nvd3 0.15.0
   Adding python-nvd3 0.15.0 to easy-install.pth file
   Installing nvd3 script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for python-dateutil==2.8.1
   Best match: python-dateutil 2.8.1
   Adding python-dateutil 2.8.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for python-daemon==2.2.4
   Best match: python-daemon 2.2.4
   Adding python-daemon 2.2.4 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Pygments==2.6.1
   Best match: Pygments 2.6.1
   Adding Pygments 2.6.1 to easy-install.pth file
   Installing pygmentize script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for psutil==5.7.0
   Best match: psutil 5.7.0
   Adding psutil 5.7.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for pendulum==2.1.1
   Best match: pendulum 2.1.1
   Adding pendulum 2.1.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for pandas==1.0.5
   Best match: pandas 1.0.5
   Adding pandas 1.0.5 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for marshmallow-oneofschema==2.0.1
   Best match: marshmallow-oneofschema 2.0.1
   Adding marshmallow-oneofschema 2.0.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for MarkupSafe==1.1.1
   Best match: MarkupSafe 1.1.1
   Adding MarkupSafe 1.1.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Markdown==2.6.11
   Best match: Markdown 2.6.11
   Adding Markdown 2.6.11 to easy-install.pth file
   Installing markdown_py script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for lockfile==0.12.2
   Best match: lockfile 0.12.2
   Adding lockfile 0.12.2 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for lazy-object-proxy==1.5.0
   Best match: lazy-object-proxy 1.5.0
   Adding lazy-object-proxy 1.5.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for jsonschema==3.2.0
   Best match: jsonschema 3.2.0
   Adding jsonschema 3.2.0 to easy-install.pth file
   Installing jsonschema script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for json-merge-patch==0.2
   Best match: json-merge-patch 0.2
   Adding json-merge-patch 0.2 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Jinja2==2.10.3
   Best match: Jinja2 2.10.3
   Adding Jinja2 2.10.3 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for iso8601==0.1.12
   Best match: iso8601 0.1.12
   Adding iso8601 0.1.12 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for gunicorn==19.10.0
   Best match: gunicorn 19.10.0
   Adding gunicorn 19.10.0 to easy-install.pth file
   Installing gunicorn script to /Users/jax/xx/pythonenv/airflowenv/bin
   Installing gunicorn_paster script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for graphviz==0.14.1
   Best match: graphviz 0.14.1
   Adding graphviz 0.14.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for funcsigs==1.0.2
   Best match: funcsigs 1.0.2
   Adding funcsigs 1.0.2 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-WTF==0.14.3
   Best match: Flask-WTF 0.14.3
   Adding Flask-WTF 0.14.3 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for flask-swagger==0.2.13
   Best match: flask-swagger 0.2.13
   Adding flask-swagger 0.2.13 to easy-install.pth file
   Installing flaskswagger script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-Login==0.4.1
   Best match: Flask-Login 0.4.1
   Adding Flask-Login 0.4.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-Caching==1.3.3
   Best match: Flask-Caching 1.3.3
   Adding Flask-Caching 1.3.3 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-AppBuilder==3.0.1
   Best match: Flask-AppBuilder 3.0.1
   Adding Flask-AppBuilder 3.0.1 to easy-install.pth file
   Installing fabmanager script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask==1.1.2
   Best match: Flask 1.1.2
   Adding Flask 1.1.2 to easy-install.pth file
   Installing flask script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for dill==0.3.2
   Best match: dill 0.3.2
   Adding dill 0.3.2 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for cryptography==2.9.2
   Best match: cryptography 2.9.2
   Adding cryptography 2.9.2 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for croniter==0.3.34
   Best match: croniter 0.3.34
   Adding croniter 0.3.34 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for connexion==2.7.0
   Best match: connexion 2.7.0
   Adding connexion 2.7.0 to easy-install.pth file
   Installing connexion script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for colorlog==4.0.2
   Best match: colorlog 4.0.2
   Adding colorlog 4.0.2 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for cattrs==1.0.0
   Best match: cattrs 1.0.0
   Adding cattrs 1.0.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for cached-property==1.5.1
   Best match: cached-property 1.5.1
   Adding cached-property 1.5.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for attrs==19.3.0
   Best match: attrs 19.3.0
   Adding attrs 19.3.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for argcomplete==1.12.0
   Best match: argcomplete 1.12.0
   Adding argcomplete 1.12.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for alembic==1.4.2
   Best match: alembic 1.4.2
   Adding alembic 1.4.2 to easy-install.pth file
   Installing alembic script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for pytz==2020.1
   Best match: pytz 2020.1
   Adding pytz 2020.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for six==1.15.0
   Best match: six 1.15.0
   Adding six 1.15.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for idna==2.10
   Best match: idna 2.10
   Adding idna 2.10 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for urllib3==1.25.9
   Best match: urllib3 1.25.9
   Adding urllib3 1.25.9 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for chardet==3.0.4
   Best match: chardet 3.0.4
   Adding chardet 3.0.4 to easy-install.pth file
   Installing chardetect script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for certifi==2020.6.20
   Best match: certifi 2020.6.20
   Adding certifi 2020.6.20 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for text-unidecode==1.3
   Best match: text-unidecode 1.3
   Adding text-unidecode 1.3 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for docutils==0.16
   Best match: docutils 0.16
   Adding docutils 0.16 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for setuptools==49.6.0
   Best match: setuptools 49.6.0
   Adding setuptools 49.6.0 to easy-install.pth file
   Installing easy_install script to /Users/jax/xx/pythonenv/airflowenv/bin
   Installing easy_install-3.8 script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for pytzdata==2020.1
   Best match: pytzdata 2020.1
   Adding pytzdata 2020.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for numpy==1.19.0
   Best match: numpy 1.19.0
   Adding numpy 1.19.0 to easy-install.pth file
   Installing f2py script to /Users/jax/xx/pythonenv/airflowenv/bin
   Installing f2py3 script to /Users/jax/xx/pythonenv/airflowenv/bin
   Installing f2py3.8 script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for marshmallow==3.7.0
   Best match: marshmallow 3.7.0
   Adding marshmallow 3.7.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for pyrsistent==0.16.0
   Best match: pyrsistent 0.16.0
   Adding pyrsistent 0.16.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for itsdangerous==1.1.0
   Best match: itsdangerous 1.1.0
   Adding itsdangerous 1.1.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for WTForms==2.3.1
   Best match: WTForms 2.3.1
   Adding WTForms 2.3.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for PyYAML==5.3.1
   Best match: PyYAML 5.3.1
   Adding PyYAML 5.3.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for apispec==3.3.1
   Best match: apispec 3.3.1
   Adding apispec 3.3.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for click==6.7
   Best match: click 6.7
   Adding click 6.7 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-OpenID==1.2.5
   Best match: Flask-OpenID 1.2.5
   Adding Flask-OpenID 1.2.5 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for colorama==0.4.3
   Best match: colorama 0.4.3
   Adding colorama 0.4.3 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for PyJWT==1.7.1
   Best match: PyJWT 1.7.1
   Adding PyJWT 1.7.1 to easy-install.pth file
   Installing pyjwt script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for SQLAlchemy-Utils==0.36.8
   Best match: SQLAlchemy-Utils 0.36.8
   Adding SQLAlchemy-Utils 0.36.8 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for email-validator==1.1.1
   Best match: email-validator 1.1.1
   Adding email-validator 1.1.1 to easy-install.pth file
   Installing email_validator script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-SQLAlchemy==2.4.4
   Best match: Flask-SQLAlchemy 2.4.4
   Adding Flask-SQLAlchemy 2.4.4 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-JWT-Extended==3.24.1
   Best match: Flask-JWT-Extended 3.24.1
   Adding Flask-JWT-Extended 3.24.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for prison==0.1.3
   Best match: prison 0.1.3
   Adding prison 0.1.3 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for marshmallow-sqlalchemy==0.23.1
   Best match: marshmallow-sqlalchemy 0.23.1
   Adding marshmallow-sqlalchemy 0.23.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Flask-Babel==1.0.0
   Best match: Flask-Babel 1.0.0
   Adding Flask-Babel 1.0.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for marshmallow-enum==1.5.1
   Best match: marshmallow-enum 1.5.1
   Adding marshmallow-enum 1.5.1 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for cffi==1.14.0
   Best match: cffi 1.14.0
   Adding cffi 1.14.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for natsort==7.0.1
   Best match: natsort 7.0.1
   Adding natsort 7.0.1 to easy-install.pth file
   Installing natsort script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for swagger-ui-bundle==0.0.6
   Best match: swagger-ui-bundle 0.0.6
   Adding swagger-ui-bundle 0.0.6 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for openapi-spec-validator==0.2.8
   Best match: openapi-spec-validator 0.2.8
   Adding openapi-spec-validator 0.2.8 to easy-install.pth file
   Installing openapi-spec-validator script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for clickclick==1.2.2
   Best match: clickclick 1.2.2
   Adding clickclick 1.2.2 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for inflection==0.5.0
   Best match: inflection 0.5.0
   Adding inflection 0.5.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for python-editor==1.0.4
   Best match: python-editor 1.0.4
   Adding python-editor 1.0.4 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Mako==1.1.3
   Best match: Mako 1.1.3
   Adding Mako 1.1.3 to easy-install.pth file
   Installing mako-render script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for python3-openid==3.2.0
   Best match: python3-openid 3.2.0
   Adding python3-openid 3.2.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for dnspython==1.16.0
   Best match: dnspython 1.16.0
   Adding dnspython 1.16.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for Babel==2.8.0
   Best match: Babel 2.8.0
   Adding Babel 2.8.0 to easy-install.pth file
   Installing pybabel script to /Users/jax/xx/pythonenv/airflowenv/bin
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for pycparser==2.20
   Best match: pycparser 2.20
   Adding pycparser 2.20 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Searching for defusedxml==0.6.0
   Best match: defusedxml 0.6.0
   Adding defusedxml 0.6.0 to easy-install.pth file
   
   Using /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages
   Finished processing dependencies for apache-airflow==2.0.0.dev0
   (airflowenv) ➜ airflow git:(master) ✗
   (airflowenv) ➜ airflow git:(master) ✗
   (airflowenv) ➜ airflow git:(master) ✗
   ```
   <!-- (please include exact error messages if you can) -->
   
   **What you expected to happen**:
   
   <!-- What do you think went wrong? -->
   ```
   (airflowenv) ➜ airflow git:(master) ✗
   (airflowenv) ➜ airflow git:(master) ✗
   (airflowenv) ➜ airflow git:(master) ✗ airflow --help
   Traceback (most recent call last):
     File "/usr/local/bin/airflow", line 6, in <module>
       from pkg_resources import load_entry_point
     File "/Library/Frameworks/Python.framework/Versions/3.8/lib/python3.8/site-packages/pkg_resources/__init__.py", line 3262, in <module>
       def _initialize_master_working_set():
     File "/Library/Frameworks/Python.framework/Versions/3.8/lib/python3.8/site-packages/pkg_resources/__init__.py", line 3245, in _call_aside
       f(*args, **kwargs)
     File "/Library/Frameworks/Python.framework/Versions/3.8/lib/python3.8/site-packages/pkg_resources/__init__.py", line 3274, in _initialize_master_working_set
       working_set = WorkingSet._build_master()
     File "/Library/Frameworks/Python.framework/Versions/3.8/lib/python3.8/site-packages/pkg_resources/__init__.py", line 584, in _build_master
       ws.require(__requires__)
     File "/Library/Frameworks/Python.framework/Versions/3.8/lib/python3.8/site-packages/pkg_resources/__init__.py", line 901, in require
       needed = self.resolve(parse_requirements(requirements))
     File "/Library/Frameworks/Python.framework/Versions/3.8/lib/python3.8/site-packages/pkg_resources/__init__.py", line 787, in resolve
       raise DistributionNotFound(req, requirers)
   pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application
   (airflowenv) ➜ airflow git:(master) ✗
   (airflowenv) ➜ airflow git:(master) ✗
   ```
   
   
   **How to reproduce it**:
   <!---
   
   As minimally and precisely as possible. Keep in mind we do not have access to your cluster or dags.
   
   If you are using kubernetes, please attempt to recreate the issue using minikube or kind.
   
   ## Install minikube/kind
   
   - Minikube https://minikube.sigs.k8s.io/docs/start/
   - Kind https://kind.sigs.k8s.io/docs/user/quick-start/
   
   If this is a UI bug, please provide a screenshot of the bug or a link to a youtube video of the bug in action
   
   You can include images using the .md style of
   ![alt text](http://url/to/img.png)
   
   To record a screencast, mac users can use QuickTime and then create an unlisted youtube video with the resulting .mov file.
   
   --->
   
   
   **Anything else we need to know**:
   
   <!--
   
   How often does this problem occur? Once? Every time etc?
   
   Any relevant logs to include? Put them here in side a detail tag:
   <details><summary>x.log</summary> lots of stuff </details>
   
   -->
   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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



[GitHub] [airflow] potiuk closed issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

Posted by GitBox <gi...@apache.org>.
potiuk closed issue #10516:
URL: https://github.com/apache/airflow/issues/10516


   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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



[GitHub] [airflow] potiuk commented on issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

Posted by GitBox <gi...@apache.org>.
potiuk commented on issue #10516:
URL: https://github.com/apache/airflow/issues/10516#issuecomment-682149537


   @xu-xiang - can you please try to replicate using the latest master and the standard virtualenv we recommend in CONTRIbUTING (with pyenv or mkvirtualenv and report if you have a success ? I think this.might be about some non-standard virtualenv setting you have 


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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



[GitHub] [airflow] potiuk edited a comment on issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

Posted by GitBox <gi...@apache.org>.
potiuk edited a comment on issue #10516:
URL: https://github.com/apache/airflow/issues/10516#issuecomment-679881303


   This is because you need to install airflow using older version of PIP (19.0.2). @kaxil and others - should we finally try to see what it take to migrate to the latest version? Anyone remembers why we are pinned to 19.0.2 ? 


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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



[GitHub] [airflow] xu-xiang commented on issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

Posted by GitBox <gi...@apache.org>.
xu-xiang commented on issue #10516:
URL: https://github.com/apache/airflow/issues/10516#issuecomment-681316952


   ```
   (airflowenv) ➜ pythonenv pip --version
   pip 20.2.2 from /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages/pip (python 3.8)
   (airflowenv) ➜ pythonenv
   (airflowenv) ➜ pythonenv pip3 --version
   pip 20.2.2 from /Users/jax/xx/pythonenv/airflowenv/lib/python3.8/site-packages/pip (python 3.8)
   (airflowenv) ➜ pythonenv
   ```


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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



[GitHub] [airflow] potiuk commented on issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

Posted by GitBox <gi...@apache.org>.
potiuk commented on issue #10516:
URL: https://github.com/apache/airflow/issues/10516#issuecomment-679906396


   Hello @xu-xiang. I just installed Airflow using the latest PIP version (and using the command you provided). It works for me for python 3.8 on Linux. The only thing that I can thing you might have problem with is PIP version (19.0.3 and above < 20.0.0) had a bug that made us pin to 19.0.2. Since PIP 20.2.+ works fine, I got rid of the 19.0.2 pinning in Docker images with #10542. Could you please verify if you have latest pip/easy_install installed and try again ? 


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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



[GitHub] [airflow] xu-xiang commented on issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

Posted by GitBox <gi...@apache.org>.
xu-xiang commented on issue #10516:
URL: https://github.com/apache/airflow/issues/10516#issuecomment-681318818


   @potiuk My pip version is 20.2.2  when i create this issues.
   Use `(airflowenv) ➜ airflow git:(master) ✗ python3.8 setup.py install` install airflow  and error with `pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application`


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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



[GitHub] [airflow] potiuk commented on issue #10516: pkg_resources.DistributionNotFound: The 'apache-airflow==2.0.0.dev0' distribution was not found and is required by the application

Posted by GitBox <gi...@apache.org>.
potiuk commented on issue #10516:
URL: https://github.com/apache/airflow/issues/10516#issuecomment-679881303


   This is because you need to install airflow using older version of PIP (19.0.2). @kaxil and others - shoudl we finally try to see what it take to migrate to the latest version? Anyone remembers why we are pinned to 19.0.2 ? 


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to 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