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/20 12:43:23 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #853

See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/853/display/redirect>

------------------------------------------
[...truncated 33.92 KB...]
        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

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: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.CombineTest$CombineWithContextTests > testSimpleCombineWithContextEmpty FAILED
    java.lang.RuntimeException at CombineTest.java:975
        Caused by: java.lang.RuntimeException at CombineTest.java:975
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:975
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

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

org.apache.beam.sdk.transforms.KeysTest > testKeysEmpty FAILED
    java.lang.AssertionError at KeysTest.java:73

org.apache.beam.sdk.transforms.KvSwapTest > testKvSwap FAILED
    java.lang.AssertionError at KvSwapTest.java:77

org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests > testGroupByKeyMergingWindows FAILED
    java.lang.AssertionError at GroupByKeyTest.java:480

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

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testWindowedCombineGloballyAsSingletonView FAILED
    java.lang.RuntimeException at CombineTest.java:1369
        Caused by: java.lang.RuntimeException at CombineTest.java:1369
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:1369
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testCombineGloballyInstanceMethodReference FAILED
    java.lang.RuntimeException at CombineTest.java:1403
        Caused by: java.lang.RuntimeException at CombineTest.java:1403
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:1403
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

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: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testFixedWindowsCombineWithContext FAILED
    java.lang.AssertionError at CombineTest.java:1072

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSessionsCombineWithContext FAILED
    java.lang.AssertionError at CombineTest.java:1286

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

org.apache.beam.sdk.transforms.ParDoTest$BasicTests > testParDoEmpty FAILED
    java.lang.RuntimeException at ParDoTest.java:362
        Caused by: java.lang.RuntimeException at ParDoTest.java:362
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:362
                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$AccumulationTests > testAccumulatingCombine FAILED
    java.lang.RuntimeException at CombineTest.java:1417
        Caused by: java.lang.RuntimeException at CombineTest.java:1417
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:1417
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWrite FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:140
        Caused by: java.lang.RuntimeException at ParDoSchemaTest.java:140
            Caused by: java.util.concurrent.ExecutionException at ParDoSchemaTest.java:140
                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.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
                        Caused by: java.io.IOException

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

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteWithSchemaRegistry FAILED
    java.lang.AssertionError at ParDoSchemaTest.java:279

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 > testValueStateCoderInferenceFromInputCoder FAILED
    java.lang.AssertionError at ParDoTest.java:3305

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
                        Caused by: java.io.IOException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputsIsCumulative FAILED
    java.lang.RuntimeException at ParDoTest.java:847
        Caused by: java.lang.RuntimeException at ParDoTest.java:847
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:847
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputs FAILED
    java.lang.RuntimeException at ParDoTest.java:737
        Caused by: java.lang.RuntimeException at ParDoTest.java:737
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:737
                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$LifecycleTests > testWindowingInStartAndFinishBundle FAILED
    java.lang.AssertionError at ParDoTest.java:1220

org.apache.beam.sdk.transforms.windowing.WindowingTest > testNonPartitioningWindowing FAILED
    java.lang.AssertionError at WindowingTest.java:150

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

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.v1p13p1.io.grpc.StatusRuntimeException

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.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: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.ReifyTimestampsTest > inValuesSucceeds FAILED
    java.lang.AssertionError at ReifyTimestampsTest.java:60
[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:32805
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:33655
[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
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:39397
[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
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:34321
[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
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:43401
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:43179
[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
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:45295
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:34477
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:44535
[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
[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
[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
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:33617
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:33409
[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:40807
[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
[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:34671
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:38999
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:41149
[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
[TransientBlobCache shutdown hook] INFO org.apache.flink.runtime.blob.TransientBlobCache - Shutting down BLOB cache
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:40983

196 tests completed, 41 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 31m 27s
62 actionable tasks: 41 executed, 21 from cache

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

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

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


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