You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@arrow.apache.org by jo...@apache.org on 2022/07/19 12:19:56 UTC

[arrow] branch master updated: ARROW-17108: [Python] Stop skipping dask tests on integration jobs (#13636)

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

jorisvandenbossche pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/arrow.git


The following commit(s) were added to refs/heads/master by this push:
     new 4e9053bbdb ARROW-17108: [Python] Stop skipping dask tests on integration jobs (#13636)
4e9053bbdb is described below

commit 4e9053bbdb32ac56472f9b8da7c3eab3a8c802c1
Author: Raúl Cumplido <ra...@gmail.com>
AuthorDate: Tue Jul 19 14:19:50 2022 +0200

    ARROW-17108: [Python] Stop skipping dask tests on integration jobs (#13636)
    
    Some of the previously skipped tests for dask integration tests are already fixed and we don't require to skip them anymore.
    
    Authored-by: Raúl Cumplido <ra...@gmail.com>
    Signed-off-by: Joris Van den Bossche <jo...@gmail.com>
---
 ci/scripts/integration_dask.sh | 10 ++--------
 1 file changed, 2 insertions(+), 8 deletions(-)

diff --git a/ci/scripts/integration_dask.sh b/ci/scripts/integration_dask.sh
index 313040014a..eeaba715b6 100755
--- a/ci/scripts/integration_dask.sh
+++ b/ci/scripts/integration_dask.sh
@@ -28,17 +28,11 @@ python -c "import pyarrow.parquet"
 python -c "import dask.dataframe"
 
 # TODO(kszucs): the following tests are also uses pyarrow
-# pytest -sv --pyargs dask.bytes.tests.test_s3
 # pytest -sv --pyargs dask.bytes.tests.test_hdfs
 # pytest -sv --pyargs dask.bytes.tests.test_local
 
-# 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 and not test_describe_empty"
+pytest -v --pyargs dask.dataframe.tests.test_dataframe
 pytest -v --pyargs dask.dataframe.io.tests.test_orc
-# skip failing parquet tests, see https://github.com/dask/dask/issues/6243
-# test_pandas_timestamp_overflow_pyarrow is skipped because of ARROW-15720 - can be removed once 2022.02.1 is out
-pytest -v --pyargs dask.dataframe.io.tests.test_parquet \
-  -k "not test_to_parquet_pyarrow_w_inconsistent_schema_by_partition_fails_by_default and not test_timeseries_nulls_in_schema and not test_pandas_timestamp_overflow_pyarrow"
-
+pytest -v --pyargs dask.dataframe.io.tests.test_parquet
 # this file contains parquet tests that use S3 filesystem
 pytest -v --pyargs dask.bytes.tests.test_s3