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/18 09:31:21 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Batch #807

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

Changes:

[echauchot] [BEAM-4164] Add Cassandra embedded cluster + start and stop methods

[echauchot] [BEAM-4164] Add Cassandra embedded cluster purge

[echauchot] [BEAM-4164] Add rows insert and manual refresh of the cluster

[echauchot] [BEAM-4164] Remove CassandraService (as its main use was to inject a

[echauchot] [BEAM-4164] Rename Mutate<T> to Write<T> for consistency among the IOs.

[echauchot] [BEAM-4164] Rename one of the split methods and regroup getEstimatedSize

[echauchot] [BEAM-4164] Remove Writer and Deleter classes because they were just

[echauchot] [BEAM-4164] Fix comments

[echauchot] [BEAM-4164] Move former CassandraServiceImplTest utils tests to

[echauchot] [BEAM-4164] Split back getEstimatedSizeBytesFromTokenRanges to be able

[echauchot] [BEAM-4164] Use embedded cassandra instead of FakeCassandraService in

[echauchot] [BEAM-4164] Add missing testSplit

[echauchot] [BEAM-4164] Remove CassandraService and related

[echauchot] [BEAM-4164] Put mutators transient

[echauchot] [BEAM-4164] Fix deps conflict in build.

[echauchot] [BEAM-6591] Fix split

[echauchot] [BEAM-4164] Fix testDelete: missing PartitionKey

[echauchot] [BEAM-4164] Reduce test time

[echauchot] [BEAM-4164] Fix spotless

[echauchot] [BEAM-4164] remove unneeded cassandra version definition property

[echauchot] [BEAM-4164] Cassandra version was updated, size of the keyspace is not

[echauchot] [BEAM-4164] Update checkstyle exceptions to allow non-vendor guava in

------------------------------------------
[...truncated 22.92 KB...]
> Task :beam-runners-core-java:compileJava FROM-CACHE
> Task :beam-runners-core-java:classes UP-TO-DATE
> Task :beam-runners-core-construction-java:compileTestJava FROM-CACHE
> Task :beam-runners-core-construction-java:testClasses UP-TO-DATE
> 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-io-google-cloud-platform:compileJava FROM-CACHE
> Task :beam-sdks-java-io-google-cloud-platform:classes UP-TO-DATE
> Task :beam-sdks-java-harness:jar
> 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-runners-core-java:shadowTestJar
> Task :beam-sdks-java-harness:shadowJar
> 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:validatesPortableRunnerBatch

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

org.apache.beam.sdk.transforms.ViewTest > testIterableSideInput FAILED
    java.lang.AssertionError at ViewTest.java:396

org.apache.beam.sdk.transforms.ViewTest > testEmptyMapSideInput FAILED
    java.lang.AssertionError at ViewTest.java:1177

org.apache.beam.sdk.transforms.ViewTest > testWindowedMapAsEntrySetSideInput FAILED
    java.lang.AssertionError at ViewTest.java:1099

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

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

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindows FAILED
    java.lang.RuntimeException at ReshuffleTest.java:251
        Caused by: java.lang.RuntimeException at ReshuffleTest.java:251
            Caused by: java.util.concurrent.ExecutionException at ReshuffleTest.java:251
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

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

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindowsAndGroupByKey FAILED
    java.lang.RuntimeException at ReshuffleTest.java:211
        Caused by: java.lang.RuntimeException at ReshuffleTest.java:211
            Caused by: java.util.concurrent.ExecutionException at ReshuffleTest.java:211
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

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

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: java.lang.OutOfMemoryError

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

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

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

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

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

org.apache.beam.sdk.transforms.ParDoSchemaTest > testInferredSchemaPipeline FAILED
    java.lang.AssertionError at ParDoSchemaTest.java:391

org.apache.beam.sdk.transforms.ParDoSchemaTest > testFieldAccessSchemaPipeline FAILED
    java.lang.AssertionError at ParDoSchemaTest.java:313

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

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

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

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: 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 > 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: java.lang.OutOfMemoryError

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

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: org.apache.beam.vendor.grpc.v1p13p1.io.netty.util.internal.OutOfDirectMemoryError
[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
[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:39789
[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:38257
[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:40539
[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:33963
[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:42467

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

Publishing build scan...
https://gradle.com/s/56se536rykq4o

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

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


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