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 09:53:46 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Batch #833

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

Changes:

[mathieu.blanchard] [BEAM-6292] PasswordDecrypter: Delay decryption / Avoid serialization

[mathieu.blanchard] Review: Add some comments & tests

------------------------------------------
[...truncated 32.88 KB...]
    java.lang.RuntimeException at ViewTest.java:1334
        Caused by: java.lang.RuntimeException at ViewTest.java:1334
            Caused by: java.util.concurrent.ExecutionException at ViewTest.java:1334
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

org.apache.beam.sdk.transforms.ViewTest > testMultimapSideInputIsImmutable FAILED
    java.lang.AssertionError at ViewTest.java:913

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

org.apache.beam.sdk.transforms.ViewTest > testWindowedMultimapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:797
        Caused by: java.lang.RuntimeException at ViewTest.java:797
            Caused by: java.util.concurrent.ExecutionException at ViewTest.java:797
                Caused by: java.lang.OutOfMemoryError

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

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

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

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

org.apache.beam.sdk.transforms.ViewTest > testMapSideInputIsImmutable FAILED
    java.lang.AssertionError at ViewTest.java:1301

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

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

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

org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests > testGroupByKeyMultipleWindows FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:452
        Caused by: java.lang.RuntimeException at GroupByKeyTest.java:452
            Caused by: java.util.concurrent.ExecutionException at GroupByKeyTest.java:452
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

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

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

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

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

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.ReshuffleTest > testReshuffleAfterSessionsAndGroupByKey FAILED
    java.lang.RuntimeException at ReshuffleTest.java:169
        Caused by: java.lang.RuntimeException at ReshuffleTest.java:169
            Caused by: java.util.concurrent.ExecutionException at ReshuffleTest.java:169
                Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError

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

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

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindowsAndGroupByKey FAILED
    java.lang.AssertionError at ReshuffleTest.java:211

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testCombinePerKeyInstanceMethodReference FAILED
    java.lang.RuntimeException at CombineTest.java:921
        Caused by: java.lang.RuntimeException at CombineTest.java:921
            Caused by: java.util.concurrent.ExecutionException at CombineTest.java:921
                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: java.lang.OutOfMemoryError

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

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

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

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsShouldApplyTimestamps FAILED
    java.lang.AssertionError at WithTimestampsTest.java:78

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsBackwardsInTimeAndWithAllowedTimestampSkewShouldSucceed FAILED
    java.lang.AssertionError at WithTimestampsTest.java:142

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsLambdaShouldApplyTimestamps FAILED
    java.lang.AssertionError at WithTimestampsTest.java:205
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:34757
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:38841
[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:44245
[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:32969
[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
[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
[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:46409
[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:46121
[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
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:44807
[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:40437
[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
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:46485

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

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

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

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


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