You are viewing a plain text version of this content. The canonical link for it is here.
Posted to builds@beam.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2020/01/15 23:30:09 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Spark_Batch #1812

See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Spark_Batch/1812/display/redirect?page=changes>

Changes:

[hannahjiang] [BEAM-9084] cleaning up docker image tag

[hannahjiang] [BEAM-9084] fix Java spotless

[crites] Changes watermark advance from 1001 to 1000 since Dataflow TestStream

[lukecwik] [BEAM-9030] Migrate Beam to use beam-vendor-grpc-1_26_0 (#10578)


------------------------------------------
[...truncated 66.67 KB...]
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputs FAILED
    java.lang.RuntimeException at ParDoTest.java:1107
        Caused by: java.lang.RuntimeException at ParDoTest.java:1107
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1107
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testSideInputsWithMultipleWindows FAILED
    java.lang.RuntimeException at ParDoTest.java:1193
        Caused by: java.lang.RuntimeException at ParDoTest.java:1193
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1193
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoEmptyWithTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:648
        Caused by: java.lang.RuntimeException at ParDoTest.java:648
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:648
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:606
        Caused by: java.lang.RuntimeException at ParDoTest.java:606
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:606
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputsIsCumulative FAILED
    java.lang.RuntimeException at ParDoTest.java:1145
        Caused by: java.lang.RuntimeException at ParDoTest.java:1145
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1145
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testSideInputAnnotationWithMultipleSideInputs FAILED
    java.lang.RuntimeException at ParDoTest.java:1035

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testSideInputAnnotation FAILED
    java.lang.RuntimeException at ParDoTest.java:932
        Caused by: java.lang.RuntimeException at ParDoTest.java:932
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:932
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithEmptyTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:672
        Caused by: java.lang.RuntimeException at ParDoTest.java:672
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:672
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputs FAILED
    java.lang.RuntimeException at ParDoTest.java:751
        Caused by: java.lang.RuntimeException at ParDoTest.java:751
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:751
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputsIsCumulative FAILED
    java.lang.RuntimeException at ParDoTest.java:1069
        Caused by: java.lang.RuntimeException at ParDoTest.java:1069
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1069
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testMergingWindowing FAILED
    java.lang.RuntimeException at WindowingTest.java:168
        Caused by: java.lang.RuntimeException at WindowingTest.java:168
            Caused by: java.util.concurrent.ExecutionException at WindowingTest.java:168
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testWindowPreservation FAILED
    java.lang.RuntimeException at WindowingTest.java:197
        Caused by: java.lang.RuntimeException at WindowingTest.java:197
            Caused by: java.util.concurrent.ExecutionException at WindowingTest.java:197
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testNonPartitioningWindowing FAILED
    java.lang.RuntimeException at WindowingTest.java:150
        Caused by: java.lang.RuntimeException at WindowingTest.java:150
            Caused by: java.util.concurrent.ExecutionException at WindowingTest.java:150
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testPartitioningWindowing FAILED
    java.lang.RuntimeException at WindowingTest.java:126
        Caused by: java.lang.RuntimeException at WindowingTest.java:126
            Caused by: java.util.concurrent.ExecutionException at WindowingTest.java:126
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerEndOfWindow FAILED
    java.lang.RuntimeException at WindowTest.java:498

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerDefault FAILED
    java.lang.RuntimeException at WindowTest.java:468
        Caused by: java.lang.RuntimeException at WindowTest.java:468
            Caused by: java.util.concurrent.ExecutionException at WindowTest.java:468
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.windowing.WindowTest > testNoWindowFnDoesNotReassignWindows FAILED
    java.lang.RuntimeException at WindowTest.java:434
        Caused by: java.lang.RuntimeException at WindowTest.java:434
            Caused by: java.util.concurrent.ExecutionException at WindowTest.java:434
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ReifyTimestampsTest > extractFromValuesWhenValueTimestampedLaterSucceeds FAILED
    java.lang.RuntimeException at ReifyTimestampsTest.java:128
        Caused by: java.lang.RuntimeException at ReifyTimestampsTest.java:128
            Caused by: java.util.concurrent.ExecutionException at ReifyTimestampsTest.java:128
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ReifyTimestampsTest > extractFromValuesSucceeds FAILED
    java.lang.RuntimeException at ReifyTimestampsTest.java:92
        Caused by: java.lang.RuntimeException at ReifyTimestampsTest.java:92
            Caused by: java.util.concurrent.ExecutionException at ReifyTimestampsTest.java:92
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ReifyTimestampsTest > inValuesSucceeds FAILED
    java.lang.RuntimeException at ReifyTimestampsTest.java:60
        Caused by: java.lang.RuntimeException at ReifyTimestampsTest.java:60
            Caused by: java.util.concurrent.ExecutionException at ReifyTimestampsTest.java:60
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoShiftTimestamp FAILED
    java.lang.RuntimeException at ParDoTest.java:1601
        Caused by: java.lang.RuntimeException at ParDoTest.java:1601
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1601
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoShiftTimestampUnlimited FAILED
    java.lang.RuntimeException at ParDoTest.java:1690
        Caused by: java.lang.RuntimeException at ParDoTest.java:1690
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1690
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWrite FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:150
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:150
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:150
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemasPassedThrough FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:420
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:420
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:420
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException
                        Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.netty.channel.ChannelException
                            Caused by: java.lang.reflect.InvocationTargetException
                                Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.netty.channel.ChannelException
                                    Caused by: java.net.SocketException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldSelectionNested FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:633
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:633
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:633
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldSelectionUnboxing FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:542
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:542
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:542
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldDescriptorSelectionUnboxing FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:583
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:583
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:583
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testInferredSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:405
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:405
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:405
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testFieldAccessSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:327

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSimpleSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:96
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:96
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:96
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaConversionPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:453
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:453
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:453
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteWithSchemaRegistry FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:292
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:292
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:292
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.grpc.StatusRuntimeException
                        Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.netty.channel.ChannelException
                            Caused by: java.lang.reflect.InvocationTargetException
                                Caused by: org.apache.beam.vendor.grpc.v1p26p0.io.netty.channel.ChannelException
                                    Caused by: java.net.SocketException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteMultiOutput FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:247
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:247
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:247
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testNestedSchema FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:492
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:492
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:492
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.io.CountingSourceTest > testUnboundedSourceSplits FAILED
    java.lang.RuntimeException at CountingSourceTest.java:246
        Caused by: java.lang.RuntimeException at CountingSourceTest.java:246
            Caused by: java.util.concurrent.ExecutionException at CountingSourceTest.java:246
                Caused by: java.io.FileNotFoundException

org.apache.beam.sdk.io.CountingSourceTest > testBoundedSourceSplits FAILED
    java.lang.RuntimeException at CountingSourceTest.java:121

195 tests completed, 128 failed, 2 skipped

> Task :runners:spark:job-server:validatesPortableRunnerBatch FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:spark:job-server:validatesPortableRunnerBatch'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_PVR_Spark_Batch/ws/src/runners/spark/job-server/build/reports/tests/validatesPortableRunnerBatch/index.html>

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output. Run with --scan to get full insights.

* Get more help at https://help.gradle.org

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.2.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 1h 6m 23s
60 actionable tasks: 59 executed, 1 from cache

Publishing build scan...
https://gradle.com/s/5he6llmlp37oe

Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure

---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org


Jenkins build is back to normal : beam_PostCommit_Java_PVR_Spark_Batch #1813

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Spark_Batch/1813/display/redirect?page=changes>


---------------------------------------------------------------------
To unsubscribe, e-mail: builds-unsubscribe@beam.apache.org
For additional commands, e-mail: builds-help@beam.apache.org