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 2019/02/15 00:47:35 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #796

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

Changes:

[rohde.samuel] Propagate UserStateReferences to ExecutableStagePayload

------------------------------------------
[...truncated 23.97 KB...]
> Task :beam-runners-core-java:shadowJar
> Task :beam-runners-core-construction-java:shadowTestJar
> Task :beam-vendor-sdks-java-extensions-protobuf:shadowJar
> Task :beam-sdks-java-extensions-google-cloud-platform-core:shadowJar
> Task :beam-sdks-java-harness:compileJava FROM-CACHE
> Task :beam-sdks-java-harness:classes UP-TO-DATE
> Task :beam-sdks-java-harness:jar
> Task :beam-sdks-java-io-google-cloud-platform:compileJava FROM-CACHE
> Task :beam-sdks-java-io-google-cloud-platform:classes UP-TO-DATE
> Task :beam-sdks-java-io-google-cloud-platform:shadowJar
> Task :beam-sdks-java-core:shadowTestJar
> Task :beam-runners-core-java:compileTestJava FROM-CACHE
> Task :beam-runners-core-java:testClasses UP-TO-DATE
> Task :beam-sdks-java-harness:shadowJar
> Task :beam-runners-core-java:shadowTestJar
> Task :beam-runners-java-fn-execution:compileJava FROM-CACHE
> Task :beam-runners-java-fn-execution:classes UP-TO-DATE
> Task :beam-runners-java-fn-execution:shadowJar
> Task :beam-runners-reference-java:compileJava FROM-CACHE
> Task :beam-runners-reference-java:classes UP-TO-DATE
> Task :beam-runners-reference-java:shadowJar
> Task :beam-runners-reference-java:compileTestJava FROM-CACHE
> Task :beam-runners-reference-java:testClasses UP-TO-DATE
> Task :beam-runners-flink_2.11:compileJava FROM-CACHE
> Task :beam-runners-flink_2.11:classes
> Task :beam-runners-flink_2.11:shadowJar
> Task :beam-runners-flink_2.11:compileTestJava FROM-CACHE
> Task :beam-runners-flink_2.11:testClasses
> Task :beam-runners-reference-java:shadowTestJar
> Task :beam-runners-flink_2.11:shadowTestJar
> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming

org.apache.beam.sdk.transforms.join.CoGroupByKeyTest > testCoGroupByKey FAILED
    java.lang.RuntimeException at CoGroupByKeyTest.java:296
        Caused by: java.lang.RuntimeException at CoGroupByKeyTest.java:296
            Caused by: java.util.concurrent.ExecutionException at CoGroupByKeyTest.java:296
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.join.CoGroupByKeyTest > testCoGroupByKeyHandleResults FAILED
    java.lang.RuntimeException at CoGroupByKeyTest.java:466
        Caused by: java.lang.RuntimeException at CoGroupByKeyTest.java:466
            Caused by: java.util.concurrent.ExecutionException at CoGroupByKeyTest.java:466
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ViewTest > testIterableSideInputIsImmutable FAILED
    java.lang.RuntimeException at ViewTest.java:505
        Caused by: java.lang.RuntimeException at ViewTest.java:505
            Caused by: java.util.concurrent.ExecutionException at ViewTest.java:505
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateSimple FAILED
    java.lang.RuntimeException at ParDoTest.java:1426
        Caused by: java.lang.RuntimeException at ParDoTest.java:1426
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1426
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:1725
        Caused by: java.lang.RuntimeException at ParDoTest.java:1725
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1725
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testCoderInferenceOfList FAILED
    java.lang.RuntimeException at ParDoTest.java:1567
        Caused by: java.lang.RuntimeException at ParDoTest.java:1567
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1567
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateDedup FAILED
    java.lang.RuntimeException at ParDoTest.java:1476
        Caused by: java.lang.RuntimeException at ParDoTest.java:1476
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:1476
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateFixedWindows FAILED
    java.lang.AssertionError at ParDoTest.java:1615

org.apache.beam.sdk.transforms.CombineTest$CombineWithContextTests > testSimpleCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:965
        Caused by: java.lang.RuntimeException at CombineTest.java:965
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:965
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.CombineTest$CombineWithContextTests > testSimpleCombineWithContextEmpty FAILED
    java.lang.AssertionError at CombineTest.java:975

org.apache.beam.sdk.transforms.KeysTest > testKeys FAILED
    java.lang.AssertionError at KeysTest.java:60

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKeyEmpty FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:145
        Caused by: java.lang.RuntimeException at GroupByKeyTest.java:145
            Caused by: java.util.concurrent.ExecutionException at GroupByKeyTest.java:145
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys100KB FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:359
        Caused by: java.lang.RuntimeException at GroupByKeyTest.java:359
            Caused by: java.util.concurrent.ExecutionException at GroupByKeyTest.java:359
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testBasicCombine FAILED
    java.lang.RuntimeException at CombineTest.java:676
        Caused by: java.lang.RuntimeException at CombineTest.java:676
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:676
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testCombinePerKeyLambda FAILED
    java.lang.RuntimeException at CombineTest.java:907
        Caused by: java.lang.RuntimeException at CombineTest.java:907
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:907
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testSimpleCombineEmpty FAILED
    java.lang.RuntimeException at CombineTest.java:670
        Caused by: java.lang.RuntimeException at CombineTest.java:670
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:670
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSlidingWindowsCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:1182
        Caused by: java.lang.RuntimeException at CombineTest.java:1182
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:1182
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testFieldAccessSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:313
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:313
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:313
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteMultiOutput FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:234
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:234
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:234
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.transforms.ParDoTest$TimerCoderInferenceTests > testValueStateCoderInference FAILED
    java.lang.RuntimeException at ParDoTest.java:3235
        Caused by: java.lang.RuntimeException at ParDoTest.java:3235
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:3235
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

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

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoEmptyWithTaggedOutput FAILED
    java.lang.AssertionError at ParDoTest.java:634

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithTaggedOutput FAILED
    java.lang.AssertionError at ParDoTest.java:592

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputsIsCumulative FAILED
    java.lang.AssertionError at ParDoTest.java:847

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsBackwardsInTimeAndWithAllowedTimestampSkewShouldSucceed FAILED
    java.lang.RuntimeException at WithTimestampsTest.java:142
        Caused by: java.lang.RuntimeException at WithTimestampsTest.java:142
            Caused by: java.util.concurrent.ExecutionException at WithTimestampsTest.java:142
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException

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.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

org.apache.beam.sdk.io.CountingSourceTest > testBoundedSourceSplits FAILED
    java.lang.RuntimeException at CountingSourceTest.java:121
        Caused by: java.lang.RuntimeException at CountingSourceTest.java:121
            Caused by: java.util.concurrent.ExecutionException at CountingSourceTest.java:121
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError
[grpc-default-executor-216] INFO org.apache.beam.runners.fnexecution.logging.GrpcLoggingService - Logging client hanged up.
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[PermanentBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:40845
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:39371
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:40243
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:39739
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[PermanentBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:43117
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[PermanentBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[PermanentBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
[PermanentBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[PermanentBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.PermanentBlobCache - Shutting down BLOB cache
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:40149

196 tests completed, 27 failed, 2 skipped

> Task :beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-flink_2.11-job-server:validatesPortableRunnerStreaming'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/ws/src/runners/flink/job-server/build/reports/tests/validatesPortableRunnerStreaming/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 35m 26s
62 actionable tasks: 41 executed, 21 from cache

Publishing build scan...
https://gradle.com/s/opusckeqad3ag

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_Flink_Streaming #797

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


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