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/19 19:20:33 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Batch #821

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

Changes:

[drieber] Fix job_PreCommit_Java_Examples_Dataflow glob.

------------------------------------------
[...truncated 37.62 KB...]

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKey FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:128
        Caused by: java.lang.RuntimeException at GroupByKeyTest.java:128
            Caused by: java.util.concurrent.ExecutionException at GroupByKeyTest.java:128
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys10KB FAILED
    java.lang.AssertionError at GroupByKeyTest.java:353

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys10MB FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:371
        Caused by: java.lang.RuntimeException at GroupByKeyTest.java:371
            Caused by: java.util.concurrent.ExecutionException at GroupByKeyTest.java:371
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

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

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

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

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testSimpleCombineEmpty FAILED
    java.lang.AssertionError at CombineTest.java:670

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testSimpleCombine FAILED
    java.lang.AssertionError at CombineTest.java:657

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testHotKeyCombiningWithAccumulationMode FAILED
    java.lang.AssertionError at CombineTest.java:761

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testBasicCombineEmpty FAILED
    java.lang.AssertionError at CombineTest.java:687

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

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

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesLists FAILED
    java.lang.RuntimeException at FlattenTest.java:265
        Caused by: java.lang.RuntimeException at FlattenTest.java:265
            Caused by: java.util.concurrent.ExecutionException at FlattenTest.java:265
                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.FlattenTest > testFlattenInputMultipleCopies FAILED
    java.lang.RuntimeException at FlattenTest.java:162
        Caused by: java.lang.RuntimeException at FlattenTest.java:162
            Caused by: java.util.concurrent.ExecutionException at FlattenTest.java:162
                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.FlattenTest > testFlattenPCollectionsThenParDo FAILED
    java.lang.RuntimeException at FlattenTest.java:118
        Caused by: java.lang.RuntimeException at FlattenTest.java:118
            Caused by: java.util.concurrent.ExecutionException at FlattenTest.java:118
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

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

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterables FAILED
    java.lang.AssertionError at FlattenTest.java:252

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesSets FAILED
    java.lang.AssertionError at FlattenTest.java:280

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

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

org.apache.beam.sdk.transforms.CreateTest > testCreateWithKVVoidType FAILED
    java.lang.AssertionError at CreateTest.java:337

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

org.apache.beam.sdk.transforms.CreateTest > testCreate FAILED
    java.lang.AssertionError at CreateTest.java:90

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

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

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithEmptyTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:658
        Caused by: java.lang.RuntimeException at ParDoTest.java:658
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:658
                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

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerEndOfWindow FAILED
    java.lang.RuntimeException at WindowTest.java:498
        Caused by: java.lang.RuntimeException at WindowTest.java:498
            Caused by: java.util.concurrent.ExecutionException at WindowTest.java:498
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

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

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

org.apache.beam.sdk.transforms.ReifyTimestampsTest > extractFromValuesSucceeds FAILED
    java.lang.AssertionError at ReifyTimestampsTest.java:92

org.apache.beam.sdk.transforms.ReifyTimestampsTest > inValuesSucceeds FAILED
    java.lang.AssertionError at ReifyTimestampsTest.java:60

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: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError
[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:35987
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:39031
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:33811
[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:36731
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:41263
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:33537
[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
[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:43253
[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
[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
[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:38997
[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:45853
[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:39931
[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
[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
[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:45173
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:46051
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:35789
[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:46063
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:45525
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:44381

196 tests completed, 50 failed, 2 skipped

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

FAILURE: Build failed with an exception.

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

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

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_Batch #822

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


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