You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@arrow.apache.org by GitBox <gi...@apache.org> on 2020/07/09 10:13:23 UTC

[GitHub] [arrow] pitrou commented on a change in pull request #7675: ARROW-9353: [Python][CI] Disable known failures in dask integration tests

pitrou commented on a change in pull request #7675:
URL: https://github.com/apache/arrow/pull/7675#discussion_r452112505



##########
File path: ci/scripts/integration_dask.sh
##########
@@ -32,7 +32,11 @@ python -c "import dask.dataframe"
 # pytest -sv --pyargs dask.bytes.tests.test_hdfs
 # pytest -sv --pyargs dask.bytes.tests.test_local
 
-pytest -v --pyargs dask.dataframe.tests.test_dataframe
+# skip failing pickle test, see https://github.com/dask/dask/issues/6374
+pytest -v --pyargs dask.dataframe.tests.test_dataframe -k "not test_dataframe_picklable"
 pytest -v --pyargs dask.dataframe.io.tests.test_orc
+# skip failing parquet tests, see https://github.com/dask/dask/issues/6243
+# test_illegal_column_name can be removed once next dask release is out
+# (https://github.com/dask/dask/pull/6378)
 pytest -v --pyargs dask.dataframe.io.tests.test_parquet \
-  -k "not test_timestamp_index and not test_roundtrip_from_pandas"
+  -k "not test_to_parquet_pyarrow_w_inconsistent_schema_by_partition_fails_by_default and not test_timeseries_nulls_in_schema and not test_illegal_column_name"

Review comment:
       Not important IMO.




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