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 2022/01/13 22:22:29 UTC

[GitHub] [airflow] fjmacagno opened a new issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

fjmacagno opened a new issue #20862:
URL: https://github.com/apache/airflow/issues/20862


   ### Apache Airflow version
   
   2.2.3 (latest released)
   
   ### What happened
   
   I just built a fresh airflow image and when i tested it by running `airflow db init` (my normal test process, followed by `airflow webserver`) it threw the error 
   ```
   TypeError: __init__() got an unexpected keyword argument 'resolver'
   ```
   and crashed. Sounds like a dependency introduced an issue in a recent release?
   
   ### What you expected to happen
   
   It to not crash.
   
   ### How to reproduce
   
   Run `airflow db init` after using pip3 to install airflow.
   
   ### Operating System
   
   Ubuntu
   
   ### Versions of Apache Airflow Providers
   
   _No response_
   
   ### Deployment
   
   Other Docker-based deployment
   
   ### Deployment details
   
   _No response_
   
   ### Anything else
   
   ```
   airflow@341e3887ce4d:~$ airflow db init
   DB: sqlite:////usr/local/airflow/airflow.db
   /usr/local/lib/python3.8/site-packages/airflow/utils/db.py:662 SAWarning: relationship 'DagRun.serialized_dag' will copy column serialized_dag.dag_id to column dag_run.dag_id, which conflicts with relationship(s): 'BaseXCom.dag_run' (copies xcom.dag_id to dag_run.dag_id). If this is not the intention, consider if these relationships should be linked with back_populates, or if viewonly=True should be applied to one or more if they are read-only. For the less common case that foreign key constraints are partially overlapping, the orm.foreign() annotation can be used to isolate the columns that should be written towards.   To silence this warning, add the parameter 'overlaps="dag_run"' to the 'DagRun.serialized_dag' relationship. (Background on this error at: https://sqlalche.me/e/14/qzyx)
   /usr/local/lib/python3.8/site-packages/airflow/utils/db.py:662 SAWarning: relationship 'SerializedDagModel.dag_runs' will copy column serialized_dag.dag_id to column dag_run.dag_id, which conflicts with relationship(s): 'BaseXCom.dag_run' (copies xcom.dag_id to dag_run.dag_id). If this is not the intention, consider if these relationships should be linked with back_populates, or if viewonly=True should be applied to one or more if they are read-only. For the less common case that foreign key constraints are partially overlapping, the orm.foreign() annotation can be used to isolate the columns that should be written towards.   To silence this warning, add the parameter 'overlaps="dag_run"' to the 'SerializedDagModel.dag_runs' relationship. (Background on this error at: https://sqlalche.me/e/14/qzyx)
   [2022-01-13 22:09:43,819] {db.py:921} INFO - Creating tables
   INFO  [alembic.runtime.migration] Context impl SQLiteImpl.
   INFO  [alembic.runtime.migration] Will assume non-transactional DDL.
   /usr/local/lib/python3.8/site-packages/snowflake/connector/options.py:94 UserWarning: You have an incompatible version of 'pyarrow' installed (6.0.1), please install a version that adheres to: 'pyarrow<5.1.0,>=5.0.0; extra == "pandas"'
   INFO  [alembic.runtime.migration] Running upgrade  -> e3a246e0dc1, current schema
   INFO  [alembic.runtime.migration] Running upgrade e3a246e0dc1 -> 1507a7289a2f, create is_encrypted
   INFO  [alembic.runtime.migration] Running upgrade 1507a7289a2f -> 13eb55f81627, maintain history for compatibility with earlier migrations
   INFO  [alembic.runtime.migration] Running upgrade 13eb55f81627 -> 338e90f54d61, More logging into task_instance
   INFO  [alembic.runtime.migration] Running upgrade 338e90f54d61 -> 52d714495f0, job_id indices
   INFO  [alembic.runtime.migration] Running upgrade 52d714495f0 -> 502898887f84, Adding extra to Log
   INFO  [alembic.runtime.migration] Running upgrade 502898887f84 -> 1b38cef5b76e, add dagrun
   INFO  [alembic.runtime.migration] Running upgrade 1b38cef5b76e -> 2e541a1dcfed, task_duration
   INFO  [alembic.runtime.migration] Running upgrade 2e541a1dcfed -> 40e67319e3a9, dagrun_config
   INFO  [alembic.runtime.migration] Running upgrade 40e67319e3a9 -> 561833c1c74b, add password column to user
   INFO  [alembic.runtime.migration] Running upgrade 561833c1c74b -> 4446e08588, dagrun start end
   INFO  [alembic.runtime.migration] Running upgrade 4446e08588 -> bbc73705a13e, Add notification_sent column to sla_miss
   INFO  [alembic.runtime.migration] Running upgrade bbc73705a13e -> bba5a7cfc896, Add a column to track the encryption state of the 'Extra' field in connection
   INFO  [alembic.runtime.migration] Running upgrade bba5a7cfc896 -> 1968acfc09e3, add is_encrypted column to variable table
   INFO  [alembic.runtime.migration] Running upgrade 1968acfc09e3 -> 2e82aab8ef20, rename user table
   INFO  [alembic.runtime.migration] Running upgrade 2e82aab8ef20 -> 211e584da130, add TI state index
   INFO  [alembic.runtime.migration] Running upgrade 211e584da130 -> 64de9cddf6c9, add task fails journal table
   INFO  [alembic.runtime.migration] Running upgrade 64de9cddf6c9 -> f2ca10b85618, add dag_stats table
   INFO  [alembic.runtime.migration] Running upgrade f2ca10b85618 -> 4addfa1236f1, Add fractional seconds to mysql tables
   INFO  [alembic.runtime.migration] Running upgrade 4addfa1236f1 -> 8504051e801b, xcom dag task indices
   INFO  [alembic.runtime.migration] Running upgrade 8504051e801b -> 5e7d17757c7a, add pid field to TaskInstance
   INFO  [alembic.runtime.migration] Running upgrade 5e7d17757c7a -> 127d2bf2dfa7, Add dag_id/state index on dag_run table
   INFO  [alembic.runtime.migration] Running upgrade 127d2bf2dfa7 -> cc1e65623dc7, add max tries column to task instance
   INFO  [alembic.runtime.migration] Running upgrade cc1e65623dc7 -> bdaa763e6c56, Make xcom value column a large binary
   INFO  [alembic.runtime.migration] Running upgrade bdaa763e6c56 -> 947454bf1dff, add ti job_id index
   INFO  [alembic.runtime.migration] Running upgrade 947454bf1dff -> d2ae31099d61, Increase text size for MySQL (not relevant for other DBs' text types)
   INFO  [alembic.runtime.migration] Running upgrade d2ae31099d61 -> 0e2a74e0fc9f, Add time zone awareness
   INFO  [alembic.runtime.migration] Running upgrade d2ae31099d61 -> 33ae817a1ff4, kubernetes_resource_checkpointing
   INFO  [alembic.runtime.migration] Running upgrade 33ae817a1ff4 -> 27c6a30d7c24, kubernetes_resource_checkpointing
   INFO  [alembic.runtime.migration] Running upgrade 27c6a30d7c24 -> 86770d1215c0, add kubernetes scheduler uniqueness
   INFO  [alembic.runtime.migration] Running upgrade 86770d1215c0, 0e2a74e0fc9f -> 05f30312d566, merge heads
   INFO  [alembic.runtime.migration] Running upgrade 05f30312d566 -> f23433877c24, fix mysql not null constraint
   INFO  [alembic.runtime.migration] Running upgrade f23433877c24 -> 856955da8476, fix sqlite foreign key
   INFO  [alembic.runtime.migration] Running upgrade 856955da8476 -> 9635ae0956e7, index-taskfail
   INFO  [alembic.runtime.migration] Running upgrade 9635ae0956e7 -> dd25f486b8ea, add idx_log_dag
   INFO  [alembic.runtime.migration] Running upgrade dd25f486b8ea -> bf00311e1990, add index to taskinstance
   INFO  [alembic.runtime.migration] Running upgrade 9635ae0956e7 -> 0a2a5b66e19d, add task_reschedule table
   INFO  [alembic.runtime.migration] Running upgrade 0a2a5b66e19d, bf00311e1990 -> 03bc53e68815, merge_heads_2
   INFO  [alembic.runtime.migration] Running upgrade 03bc53e68815 -> 41f5f12752f8, add superuser field
   INFO  [alembic.runtime.migration] Running upgrade 41f5f12752f8 -> c8ffec048a3b, add fields to dag
   INFO  [alembic.runtime.migration] Running upgrade c8ffec048a3b -> dd4ecb8fbee3, Add schedule interval to dag
   INFO  [alembic.runtime.migration] Running upgrade dd4ecb8fbee3 -> 939bb1e647c8, task reschedule fk on cascade delete
   INFO  [alembic.runtime.migration] Running upgrade 939bb1e647c8 -> 6e96a59344a4, Make TaskInstance.pool not nullable
   INFO  [alembic.runtime.migration] Running upgrade 6e96a59344a4 -> d38e04c12aa2, add serialized_dag table
   INFO  [alembic.runtime.migration] Running upgrade d38e04c12aa2 -> b3b105409875, add root_dag_id to DAG
   INFO  [alembic.runtime.migration] Running upgrade 6e96a59344a4 -> 74effc47d867, change datetime to datetime2(6) on MSSQL tables
   INFO  [alembic.runtime.migration] Running upgrade 939bb1e647c8 -> 004c1210f153, increase queue name size limit
   INFO  [alembic.runtime.migration] Running upgrade c8ffec048a3b -> a56c9515abdc, Remove dag_stat table
   INFO  [alembic.runtime.migration] Running upgrade a56c9515abdc, 004c1210f153, 74effc47d867, b3b105409875 -> 08364691d074, Merge the four heads back together
   INFO  [alembic.runtime.migration] Running upgrade 08364691d074 -> fe461863935f, increase_length_for_connection_password
   INFO  [alembic.runtime.migration] Running upgrade fe461863935f -> 7939bcff74ba, Add DagTags table
   INFO  [alembic.runtime.migration] Running upgrade 7939bcff74ba -> a4c2fd67d16b, add pool_slots field to task_instance
   INFO  [alembic.runtime.migration] Running upgrade a4c2fd67d16b -> 852ae6c715af, Add RenderedTaskInstanceFields table
   INFO  [alembic.runtime.migration] Running upgrade 852ae6c715af -> 952da73b5eff, add dag_code table
   INFO  [alembic.runtime.migration] Running upgrade 952da73b5eff -> a66efa278eea, Add Precision to execution_date in RenderedTaskInstanceFields table
   INFO  [alembic.runtime.migration] Running upgrade a66efa278eea -> da3f683c3a5a, Add dag_hash Column to serialized_dag table
   INFO  [alembic.runtime.migration] Running upgrade da3f683c3a5a -> 92c57b58940d, Create FAB Tables
   INFO  [alembic.runtime.migration] Running upgrade 92c57b58940d -> 03afc6b6f902, Increase length of FAB ab_view_menu.name column
   INFO  [alembic.runtime.migration] Running upgrade 03afc6b6f902 -> cf5dc11e79ad, drop_user_and_chart
   INFO  [alembic.runtime.migration] Running upgrade cf5dc11e79ad -> bbf4a7ad0465, Remove id column from xcom
   INFO  [alembic.runtime.migration] Running upgrade bbf4a7ad0465 -> b25a55525161, Increase length of pool name
   INFO  [alembic.runtime.migration] Running upgrade b25a55525161 -> 3c20cacc0044, Add DagRun run_type
   INFO  [alembic.runtime.migration] Running upgrade 3c20cacc0044 -> 8f966b9c467a, Set conn_type as non-nullable
   INFO  [alembic.runtime.migration] Running upgrade 8f966b9c467a -> 8d48763f6d53, add unique constraint to conn_id
   INFO  [alembic.runtime.migration] Running upgrade 8d48763f6d53 -> e38be357a868, Add sensor_instance table
   INFO  [alembic.runtime.migration] Running upgrade e38be357a868 -> b247b1e3d1ed, Add queued by Job ID to TI
   INFO  [alembic.runtime.migration] Running upgrade b247b1e3d1ed -> e1a11ece99cc, Add external executor ID to TI
   INFO  [alembic.runtime.migration] Running upgrade e1a11ece99cc -> bef4f3d11e8b, Drop KubeResourceVersion and KubeWorkerId
   INFO  [alembic.runtime.migration] Running upgrade bef4f3d11e8b -> 98271e7606e2, Add scheduling_decision to DagRun and DAG
   INFO  [alembic.runtime.migration] Running upgrade 98271e7606e2 -> 52d53670a240, fix_mssql_exec_date_rendered_task_instance_fields_for_MSSQL
   INFO  [alembic.runtime.migration] Running upgrade 52d53670a240 -> 364159666cbd, Add creating_job_id to DagRun table
   INFO  [alembic.runtime.migration] Running upgrade 364159666cbd -> 45ba3f1493b9, add-k8s-yaml-to-rendered-templates
   INFO  [alembic.runtime.migration] Running upgrade 45ba3f1493b9 -> 849da589634d, Prefix DAG permissions.
   INFO  [alembic.runtime.migration] Running upgrade 849da589634d -> 2c6edca13270, Resource based permissions.
   /usr/local/lib/python3.8/site-packages/airflow/www/fab_security/sqla/manager.py:103 SADeprecationWarning: The from_engine() method on Inspector is deprecated and will be removed in a future release.  Please use the sqlalchemy.inspect() function on an Engine or Connection in order to acquire an Inspector. (deprecated since: 1.4)
   [2022-01-13 22:09:46,301] {manager.py:245} INFO - Inserted Role: Admin
   [2022-01-13 22:09:46,305] {manager.py:245} INFO - Inserted Role: Public
   [2022-01-13 22:09:46,308] {manager.py:763} WARNING - No user yet created, use flask fab command to do it.
   Traceback (most recent call last):
     File "/usr/local/bin/airflow", line 8, in <module>
       sys.exit(main())
     File "/usr/local/lib/python3.8/site-packages/airflow/__main__.py", line 48, in main
       args.func(args)
     File "/usr/local/lib/python3.8/site-packages/airflow/cli/cli_parser.py", line 48, in command
       return func(*args, **kwargs)
     File "/usr/local/lib/python3.8/site-packages/airflow/cli/commands/db_command.py", line 31, in initdb
       db.initdb()
     File "/usr/local/lib/python3.8/site-packages/airflow/utils/session.py", line 70, in wrapper
       return func(*args, session=session, **kwargs)
     File "/usr/local/lib/python3.8/site-packages/airflow/utils/db.py", line 592, in initdb
       upgradedb(session=session)
     File "/usr/local/lib/python3.8/site-packages/airflow/utils/session.py", line 67, in wrapper
       return func(*args, **kwargs)
     File "/usr/local/lib/python3.8/site-packages/airflow/utils/db.py", line 922, in upgradedb
       command.upgrade(config, 'heads')
     File "/usr/local/lib/python3.8/site-packages/alembic/command.py", line 320, in upgrade
       script.run_env()
     File "/usr/local/lib/python3.8/site-packages/alembic/script/base.py", line 563, in run_env
       util.load_python_file(self.dir, "env.py")
     File "/usr/local/lib/python3.8/site-packages/alembic/util/pyfiles.py", line 92, in load_python_file
       module = load_module_py(module_id, path)
     File "/usr/local/lib/python3.8/site-packages/alembic/util/pyfiles.py", line 108, in load_module_py
       spec.loader.exec_module(module)  # type: ignore
     File "<frozen importlib._bootstrap_external>", line 843, in exec_module
     File "<frozen importlib._bootstrap>", line 219, in _call_with_frames_removed
     File "/usr/local/lib/python3.8/site-packages/airflow/migrations/env.py", line 107, in <module>
       run_migrations_online()
     File "/usr/local/lib/python3.8/site-packages/airflow/migrations/env.py", line 101, in run_migrations_online
       context.run_migrations()
     File "<string>", line 8, in run_migrations
     File "/usr/local/lib/python3.8/site-packages/alembic/runtime/environment.py", line 851, in run_migrations
       self.get_context().run_migrations(**kw)
     File "/usr/local/lib/python3.8/site-packages/alembic/runtime/migration.py", line 620, in run_migrations
       step.migration_fn(**kw)
     File "/usr/local/lib/python3.8/site-packages/airflow/migrations/versions/2c6edca13270_resource_based_permissions.py", line 314, in upgrade
       remap_permissions()
     File "/usr/local/lib/python3.8/site-packages/airflow/migrations/versions/2c6edca13270_resource_based_permissions.py", line 289, in remap_permissions
       appbuilder = create_app(config={'FAB_UPDATE_PERMS': False}).appbuilder
     File "/usr/local/lib/python3.8/site-packages/airflow/www/app.py", line 131, in create_app
       init_api_connexion(flask_app)
     File "/usr/local/lib/python3.8/site-packages/airflow/www/extensions/init_views.py", line 196, in init_api_connexion
       api_bp = connexion_app.add_api(
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/apps/flask_app.py", line 57, in add_api
       api = super(FlaskApp, self).add_api(specification, **kwargs)
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/apps/abstract.py", line 144, in add_api
       api = self.api_cls(specification,
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/apis/abstract.py", line 75, in __init__
       self.specification = Specification.load(specification, arguments=arguments)
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/spec.py", line 153, in load
       return cls.from_file(spec, arguments=arguments)
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/spec.py", line 107, in from_file
       return cls.from_dict(spec)
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/spec.py", line 145, in from_dict
       return OpenAPISpecification(spec)
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/spec.py", line 38, in __init__
       self._validate_spec(raw_spec)
     File "/usr/local/lib/python3.8/site-packages/airflow/_vendor/connexion/spec.py", line 237, in _validate_spec
       validate_spec(spec)
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/shortcuts.py", line 7, in validate
       return validator_callable(spec, spec_url=spec_url)
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 49, in validate
       for err in self.iter_errors(spec, spec_url=spec_url):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 62, in iter_errors
       for err in self._iter_paths_errors(paths, dereferencer):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 168, in iter_errors
       for err in self._iter_path_errors(url, path_item):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 188, in iter_errors
       for err in self._iter_path_item_errors(url, path_item_deref):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 220, in iter_errors
       for err in self._iter_operation_errors(
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 253, in iter_errors
       for err in self._iter_parameters_errors(parameters):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 294, in iter_errors
       for err in self._iter_parameter_errors(parameter_deref):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 318, in iter_errors
       for err in self._iter_schema_errors(schema_deref):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 150, in iter_errors
       for err in self._iter_value_errors(schema_deref, default):
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/decorators.py", line 59, in wrapper
       for err in errors:
     File "/usr/local/lib/python3.8/site-packages/openapi_spec_validator/validators.py", line 342, in iter_errors
       validator = OAS30Validator(
   TypeError: __init__() got an unexpected keyword argument 'resolver'
   ```
   
   (using <details> messed up the formatting and i figured it being a little long was better than having it be all one line)
   
   ### Are you willing to submit PR?
   
   - [ ] Yes I am willing to submit a PR!
   
   ### Code of Conduct
   
   - [X] I agree to follow this project's [Code of Conduct](https://github.com/apache/airflow/blob/main/CODE_OF_CONDUCT.md)
   


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] potiuk commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   > > We should do that in our setup.py as well. Or, since the error came from the _vendor_ connexion, it may be possible to fix this in the Airflow code base. What’s our policy about modifying vendor code?
   > 
   > No formal policy AFAIK
   
   @kaxil is right we have no formal policy but I think the approach we used so far was that we do not modify vendored-in code unless we really need to do it and there is no other way. Basically the only modifications we want to have in the vendored-in code are those that are the reason on why we vendored in the code in the first place.
   
   I believe in this case it will be just easier to add it in setup.cfg - we might want to bump the connexion version anyway at some point (they are at 2.10.0 version and we vendored in 2.7.0 so the least number of changes we will have to re-apply, the better). 


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] kaxil commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   > We should do that in our setup.py as well. Or, since the error came from the _vendor_ connexion, it may be possible to fix this in the Airflow code base. What’s our policy about modifying vendor code?
   
   No formal policy AFAIK


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] fjmacagno commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   No, i am trying that now.


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] SamWheating edited a comment on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   We encountered this issue in our environment as well, and found that it was correlated with `openapi-schema-validator 0.2.0` which was released last week.
   
   https://pypi.org/project/openapi-schema-validator/#history
   
   As a quick fix you can probably just pin `openapi-schema-validator<0.2.0`.


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] potiuk closed issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] SamWheating commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   We encountered this issue in our environment as well, and found that it was correlated with `openapi-schema-validator 0.2.0` which was released last week.
   
   As a quick fix you can probably just pin `openapi-schema-validator<0.2.0`.


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] fjmacagno commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   Adding a constraints file fixed the issue, but it sounds like this may still be something that needs to be handled? I will leave it open, feel free to close if it isn't.


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] uranusjr commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   We should do that in our setup.py as well. Or, since the error came from the _vendor_ connexion, it may be possible to fix this in the Airflow code base. What’s our policy about modifying vendor code?


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] mik-laj commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

Posted by GitBox <gi...@apache.org>.
mik-laj commented on issue #20862:
URL: https://github.com/apache/airflow/issues/20862#issuecomment-1012597054


   Do you use constraint files to install Airflow?
   https://airflow.apache.org/docs/apache-airflow/stable/installation/installing-from-pypi.html#constraints-files


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] potiuk commented on issue #20862: Unexpected keyword argument 'resolver' during `airflow db init`

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


   Fixed by #20910 


-- 
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.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org