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 00:34:00 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #822

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

------------------------------------------
[...truncated 39.11 KB...]

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

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

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

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

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesCollections FAILED
    java.lang.AssertionError at FlattenTest.java:297

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

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesEmpty FAILED
    java.lang.RuntimeException at FlattenTest.java:312
        Caused by: java.lang.RuntimeException at FlattenTest.java:312
            Caused by: java.util.concurrent.ExecutionException at FlattenTest.java:312
                Caused by: java.lang.OutOfMemoryError

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

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsEmpty FAILED
    java.lang.RuntimeException at FlattenTest.java:130
        Caused by: java.lang.RuntimeException at FlattenTest.java:130
            Caused by: java.util.concurrent.ExecutionException at FlattenTest.java:130
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

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

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesSets FAILED
    java.lang.RuntimeException at FlattenTest.java:280
        Caused by: java.lang.RuntimeException at FlattenTest.java:280
            Caused by: java.util.concurrent.ExecutionException at FlattenTest.java:280
                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: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

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

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: 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 > 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.AssertionError at ParDoSchemaTest.java:404

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

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 > testParDoWithOnlyTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:687
        Caused by: java.lang.RuntimeException at ParDoTest.java:687
            Caused by: java.util.concurrent.ExecutionException at ParDoTest.java:687
                Caused by: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException

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

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.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 > 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 > 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: 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 > inValuesSucceeds FAILED
    java.lang.RuntimeException at ReifyTimestampsTest.java:60
        Caused by: java.lang.RuntimeException at ReifyTimestampsTest.java:60
            Caused by: java.util.concurrent.ExecutionException at ReifyTimestampsTest.java:60
                Caused by: java.lang.OutOfMemoryError

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: java.lang.RuntimeException
                    Caused by: org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException
                        Caused by: java.io.IOException
[grpc-default-executor-356] INFO org.apache.beam.runners.fnexecution.logging.GrpcLoggingService - Logging client hanged up.
[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:38033
[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:39237
[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
[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:41645
[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:42431
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:44619
[BlobServer shutdown hook] INFO org.apache.flink.runtime.blob.BlobServer - Stopped BLOB server at 0.0.0.0:40985

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

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

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

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/beam_PostCommit_Java_PVR_Flink_Streaming/823/display/redirect>


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