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/05/02 00:20:13 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Flink_Streaming #1497

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

Changes:

[kcweaver] [BEAM-7201] Go README: update task name

------------------------------------------
[...truncated 80.57 KB...]
org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldSelectionNested FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:623
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:623
            Caused by: java.io.IOException at ParDoSchemaTest.java:623
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldSelectionUnboxing FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:532
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:532
            Caused by: java.io.IOException at ParDoSchemaTest.java:532
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldDescriptorSelectionUnboxing FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:573
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:573
            Caused by: java.io.IOException at ParDoSchemaTest.java:573
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testInferredSchemaPipeline FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:395
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:395
            Caused by: java.io.IOException at ParDoSchemaTest.java:395
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testFieldAccessSchemaPipeline FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:318
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:318
            Caused by: java.io.IOException at ParDoSchemaTest.java:318
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSimpleSchemaPipeline FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:93
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:93
            Caused by: java.io.IOException at ParDoSchemaTest.java:93
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaConversionPipeline FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:443
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:443
            Caused by: java.io.IOException at ParDoSchemaTest.java:443
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteWithSchemaRegistry FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:284
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:284
            Caused by: java.io.IOException at ParDoSchemaTest.java:284
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteMultiOutput FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:239
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:239
            Caused by: java.io.IOException at ParDoSchemaTest.java:239
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoSchemaTest > testNestedSchema FAILED
    java.lang.IllegalArgumentException at ParDoSchemaTest.java:482
        Caused by: java.lang.reflect.InvocationTargetException at ParDoSchemaTest.java:482
            Caused by: java.io.IOException at ParDoSchemaTest.java:482
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$TimerCoderInferenceTests > testValueStateCoderInferenceFromInputCoder FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:3310
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:3310
            Caused by: java.io.IOException at ParDoTest.java:3310
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$TimerCoderInferenceTests > testValueStateCoderInference FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:3240
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:3240
            Caused by: java.io.IOException at ParDoTest.java:3240
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithOnlyTaggedOutput FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:688
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:688
            Caused by: java.io.IOException at ParDoTest.java:688
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputs FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:810
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:810
            Caused by: java.io.IOException at ParDoTest.java:810
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testSideInputsWithMultipleWindows FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:896
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:896
            Caused by: java.io.IOException at ParDoTest.java:896
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoEmptyWithTaggedOutput FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:635
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:635
            Caused by: java.io.IOException at ParDoTest.java:635
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithTaggedOutput FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:593
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:593
            Caused by: java.io.IOException at ParDoTest.java:593
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputsIsCumulative FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:848
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:848
            Caused by: java.io.IOException at ParDoTest.java:848
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithEmptyTaggedOutput FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:659
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:659
            Caused by: java.io.IOException at ParDoTest.java:659
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputs FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:738
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:738
            Caused by: java.io.IOException at ParDoTest.java:738
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputsIsCumulative FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:772
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:772
            Caused by: java.io.IOException at ParDoTest.java:772
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ParDoTest$LifecycleTests > testWindowingInStartAndFinishBundle FAILED
    java.lang.IllegalArgumentException at ParDoTest.java:1221
        Caused by: java.lang.reflect.InvocationTargetException at ParDoTest.java:1221
            Caused by: java.io.IOException at ParDoTest.java:1221
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testMergingWindowing FAILED
    java.lang.IllegalArgumentException at WindowingTest.java:168
        Caused by: java.lang.reflect.InvocationTargetException at WindowingTest.java:168
            Caused by: java.io.IOException at WindowingTest.java:168
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testWindowPreservation FAILED
    java.lang.IllegalArgumentException at WindowingTest.java:197
        Caused by: java.lang.reflect.InvocationTargetException at WindowingTest.java:197
            Caused by: java.io.IOException at WindowingTest.java:197
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testNonPartitioningWindowing FAILED
    java.lang.IllegalArgumentException at WindowingTest.java:150
        Caused by: java.lang.reflect.InvocationTargetException at WindowingTest.java:150
            Caused by: java.io.IOException at WindowingTest.java:150
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.windowing.WindowingTest > testPartitioningWindowing FAILED
    java.lang.IllegalArgumentException at WindowingTest.java:126
        Caused by: java.lang.reflect.InvocationTargetException at WindowingTest.java:126
            Caused by: java.io.IOException at WindowingTest.java:126
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerEndOfWindow FAILED
    java.lang.IllegalArgumentException at WindowTest.java:498
        Caused by: java.lang.reflect.InvocationTargetException at WindowTest.java:498
            Caused by: java.io.IOException at WindowTest.java:498
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerDefault FAILED
    java.lang.IllegalArgumentException at WindowTest.java:468
        Caused by: java.lang.reflect.InvocationTargetException at WindowTest.java:468
            Caused by: java.io.IOException at WindowTest.java:468
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.windowing.WindowTest > testNoWindowFnDoesNotReassignWindows FAILED
    java.lang.IllegalArgumentException at WindowTest.java:434
        Caused by: java.lang.reflect.InvocationTargetException at WindowTest.java:434
            Caused by: java.io.IOException at WindowTest.java:434
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsShouldApplyTimestamps FAILED
    java.lang.IllegalArgumentException at WithTimestampsTest.java:78
        Caused by: java.lang.reflect.InvocationTargetException at WithTimestampsTest.java:78
            Caused by: java.io.IOException at WithTimestampsTest.java:78
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsBackwardsInTimeAndWithAllowedTimestampSkewShouldSucceed FAILED
    java.lang.IllegalArgumentException at WithTimestampsTest.java:142
        Caused by: java.lang.reflect.InvocationTargetException at WithTimestampsTest.java:142
            Caused by: java.io.IOException at WithTimestampsTest.java:142
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsLambdaShouldApplyTimestamps FAILED
    java.lang.IllegalArgumentException at WithTimestampsTest.java:205
        Caused by: java.lang.reflect.InvocationTargetException at WithTimestampsTest.java:205
            Caused by: java.io.IOException at WithTimestampsTest.java:205
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ReifyTimestampsTest > extractFromValuesWhenValueTimestampedLaterSucceeds FAILED
    java.lang.IllegalArgumentException at ReifyTimestampsTest.java:128
        Caused by: java.lang.reflect.InvocationTargetException at ReifyTimestampsTest.java:128
            Caused by: java.io.IOException at ReifyTimestampsTest.java:128
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ReifyTimestampsTest > extractFromValuesSucceeds FAILED
    java.lang.IllegalArgumentException at ReifyTimestampsTest.java:92
        Caused by: java.lang.reflect.InvocationTargetException at ReifyTimestampsTest.java:92
            Caused by: java.io.IOException at ReifyTimestampsTest.java:92
                Caused by: java.net.BindException

org.apache.beam.sdk.transforms.ReifyTimestampsTest > inValuesSucceeds FAILED
    java.lang.IllegalArgumentException at ReifyTimestampsTest.java:60
        Caused by: java.lang.reflect.InvocationTargetException at ReifyTimestampsTest.java:60
            Caused by: java.io.IOException at ReifyTimestampsTest.java:60
                Caused by: java.net.BindException

org.apache.beam.sdk.io.CountingSourceTest > testUnboundedSourceSplits FAILED
    java.lang.IllegalArgumentException at CountingSourceTest.java:246
        Caused by: java.lang.reflect.InvocationTargetException at CountingSourceTest.java:246
            Caused by: java.io.IOException at CountingSourceTest.java:246
                Caused by: java.net.BindException

org.apache.beam.sdk.io.CountingSourceTest > testBoundedSourceSplits FAILED
    java.lang.IllegalArgumentException at CountingSourceTest.java:121
        Caused by: java.lang.reflect.InvocationTargetException at CountingSourceTest.java:121
            Caused by: java.io.IOException at CountingSourceTest.java:121
                Caused by: java.net.BindException

201 tests completed, 176 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 4m 22s
65 actionable tasks: 43 executed, 22 from cache

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

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

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


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