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/06/26 22:46:58 UTC

Build failed in Jenkins: beam_PostCommit_Java_ValidatesRunner_Dataflow #2949

See <https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Dataflow/2949/display/redirect>

------------------------------------------
[...truncated 55.40 KB...]
org.apache.beam.sdk.transforms.ParDoSchemaTest > testSimpleSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:94
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:94

org.apache.beam.sdk.transforms.SplittableDoFnTest > testPairWithIndexWindowedTimestampedUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:220
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:220

org.apache.beam.sdk.transforms.ViewTest > testWindowedSideInputFixedToFixedWithDefault FAILED
    java.lang.RuntimeException at ViewTest.java:1455
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1455

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testCombineGloballyInstanceMethodReference FAILED
    java.lang.RuntimeException at CombineTest.java:1435
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1435

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateDedup FAILED
    java.lang.RuntimeException at ParDoTest.java:1477
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:1477

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys100KB FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:359
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:359

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithEmptyTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:659
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:659

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testEventTimeTimerMultipleKeys FAILED
    java.lang.RuntimeException at ParDoTest.java:2825
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:2825

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testHotKeyCombining FAILED
    java.lang.RuntimeException at CombineTest.java:740
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:740

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrder FAILED
    java.lang.RuntimeException at PAssertTest.java:397
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:397

org.apache.beam.sdk.transforms.FlattenTest > testFlattenMultipleCoders FAILED
    java.lang.RuntimeException at FlattenTest.java:184
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:184

org.apache.beam.sdk.transforms.ViewTest > testWindowedIterableSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:442
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:442

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaConversionPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:444
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:444

org.apache.beam.sdk.transforms.SplittableDoFnTest > testPairWithIndexBasicBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:153
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:153

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testFixedWindowsCombine FAILED
    java.lang.RuntimeException at CombineTest.java:1062
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1062

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateFixedWindows FAILED
    java.lang.RuntimeException at ParDoTest.java:1616
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:1616

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputs FAILED
    java.lang.RuntimeException at ParDoTest.java:738
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:738

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testPipelineOptionsParameterOnTimer FAILED
    java.lang.RuntimeException at ParDoTest.java:3184
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:3184

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testSimpleCombineEmpty FAILED
    java.lang.RuntimeException at CombineTest.java:674
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:674

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrderNotSerializable FAILED
    java.lang.RuntimeException at PAssertTest.java:183
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:183

org.apache.beam.sdk.transforms.SplittableDoFnTest > testOutputAfterCheckpointBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:311
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:311

org.apache.beam.sdk.transforms.ViewTest > testWindowedMapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:1144
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1144

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsThenParDo FAILED
    java.lang.RuntimeException at FlattenTest.java:118
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:118

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteWithSchemaRegistry FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:285
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:285

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSlidingWindowsCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:1214
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1214

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputsIsCumulative FAILED
    java.lang.RuntimeException at ParDoTest.java:772
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:772

org.apache.beam.sdk.transforms.FlattenTest > testFlattenMultiplePCollectionsHavingMultipleConsumers FAILED
    java.lang.RuntimeException at FlattenTest.java:347
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:347

org.apache.beam.sdk.testing.PAssertTest > testSerializablePredicate FAILED
    java.lang.RuntimeException at PAssertTest.java:204
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:204

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteMultiOutput FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:240
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:240

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testSimpleCombine FAILED
    java.lang.RuntimeException at CombineTest.java:661
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:661

org.apache.beam.sdk.transforms.ViewTest > testWindowedSideInputFixedToGlobal FAILED
    java.lang.RuntimeException at ViewTest.java:1416
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1416

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testFixedWindowsCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:1104
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1104

org.apache.beam.sdk.transforms.SplittableDoFnTest > testAdditionalOutputBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:637
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:637

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterables FAILED
    java.lang.RuntimeException at FlattenTest.java:252
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:252

org.apache.beam.sdk.testing.PAssertTest > testNotEqualTo FAILED
    java.lang.RuntimeException at PAssertTest.java:356
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:356

org.apache.beam.sdk.transforms.ViewTest > testMultimapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:650
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:650

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSessionsCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:1318
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1318

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testBinaryCombinePerKeyLambda FAILED
    java.lang.RuntimeException at CombineTest.java:925
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:925

org.apache.beam.sdk.transforms.ParDoSchemaTest > testNestedSchema FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:483
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:483

org.apache.beam.sdk.transforms.SplittableDoFnTest > testSideInputUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:377
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:377

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesSets FAILED
    java.lang.RuntimeException at FlattenTest.java:280
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:280

org.apache.beam.sdk.transforms.ViewTest > testEmptyMultimapSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:830
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:830

org.apache.beam.sdk.testing.PAssertTest > testGlobalWindowContainsInAnyOrder FAILED
    java.lang.RuntimeException at PAssertTest.java:406
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:406

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testHotKeyCombiningWithAccumulationMode FAILED
    java.lang.RuntimeException at CombineTest.java:765
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:765

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsEmptyThenParDo FAILED
    java.lang.RuntimeException at FlattenTest.java:224
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:224

org.apache.beam.sdk.transforms.ViewTest > testCombinedMapSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:1334
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1334

org.apache.beam.sdk.testing.PAssertTest > testEmptyFalseDefaultReasonString FAILED
    java.lang.AssertionError at PAssertTest.java:501

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testBasicCombineEmpty FAILED
    java.lang.RuntimeException at CombineTest.java:691
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:691

org.apache.beam.sdk.transforms.ViewTest > testMultimapSideInputIsImmutable FAILED
    java.lang.RuntimeException at ViewTest.java:913
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:913

org.apache.beam.sdk.testing.PAssertTest > testAssertionSiteIsCapturedWithoutMessage FAILED
    java.lang.AssertionError at PAssertTest.java:543

org.apache.beam.sdk.transforms.ViewTest > testWindowedMultimapAsEntrySetSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:747
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:747

org.apache.beam.sdk.testing.PAssertTest > testWindowedSerializablePredicate FAILED
    java.lang.RuntimeException at PAssertTest.java:238
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:238

org.apache.beam.sdk.transforms.ViewTest > testWindowedMultimapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:797
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:797

org.apache.beam.sdk.transforms.ViewTest > testWindowedMapAsEntrySetSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:1099
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1099

org.apache.beam.sdk.transforms.ViewTest > testEmptyMapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:1211
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1211

org.apache.beam.sdk.transforms.ViewTest > testMultimapAsEntrySetSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:581
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:581

221 tests completed, 160 failed, 2 skipped

> Task :runners:google-cloud-dataflow-java:validatesRunnerLegacyWorkerTest FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesRunnerLegacyWorkerTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Dataflow/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/validatesRunnerLegacyWorkerTest/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 4h 46m 45s
60 actionable tasks: 45 executed, 15 from cache

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

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_ValidatesRunner_Dataflow #2952

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


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


Build failed in Jenkins: beam_PostCommit_Java_ValidatesRunner_Dataflow #2951

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

------------------------------------------
[...truncated 43.02 KB...]
org.apache.beam.sdk.transforms.CombineFnsTest > testComposedCombine FAILED
    java.lang.RuntimeException at CombineFnsTest.java:147

org.apache.beam.sdk.transforms.SplittableDoFnTest > testPairWithIndexWindowedTimestampedBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:220
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:220

org.apache.beam.sdk.PipelineTest > testMultipleApply FAILED
    java.lang.RuntimeException at PipelineTest.java:228
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PipelineTest.java:228

org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests > testGroupByKeyMultipleWindows FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:452
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:452

org.apache.beam.sdk.transforms.join.CoGroupByKeyTest > testCoGroupByKeyHandleResults FAILED
    java.lang.RuntimeException at CoGroupByKeyTest.java:466
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CoGroupByKeyTest.java:466

org.apache.beam.sdk.testing.PAssertTest > testPAssertEqualsSingletonFalse FAILED
    java.lang.AssertionError at PAssertTest.java:370

org.apache.beam.sdk.transforms.ViewTest > testMultimapSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:543
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:543

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKey FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:128
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:128

org.apache.beam.sdk.transforms.CreateTest > testCreateWithVoidType FAILED
    java.lang.RuntimeException at CreateTest.java:325
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CreateTest.java:325

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesLists FAILED
    java.lang.RuntimeException at FlattenTest.java:265
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:265

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldSelectionUnboxing FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:533
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:533

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterFixedWindowsAndGroupByKey FAILED
    java.lang.RuntimeException at ReshuffleTest.java:190
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ReshuffleTest.java:190

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testGbkFollowedByUserTimers FAILED
    java.lang.RuntimeException at ParDoTest.java:2580
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:2580

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsLambdaShouldApplyTimestamps FAILED
    java.lang.RuntimeException at WithTimestampsTest.java:205
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at WithTimestampsTest.java:205

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSlidingWindowsCombine FAILED
    java.lang.RuntimeException at CombineTest.java:1163
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1163

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:1726
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:1726

org.apache.beam.sdk.transforms.windowing.WindowingTest > testNonPartitioningWindowing FAILED
    java.lang.RuntimeException at WindowingTest.java:150
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at WindowingTest.java:150

org.apache.beam.sdk.transforms.CombineFnsTest > testComposedCombineWithContext FAILED
    java.lang.RuntimeException at CombineFnsTest.java:208
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineFnsTest.java:208

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testBinaryCombinePerKeyInstanceMethodReference FAILED
    java.lang.RuntimeException at CombineTest.java:953
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:953

org.apache.beam.sdk.transforms.SplittableDoFnTest > testPairWithIndexWindowedTimestampedUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:220
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:220

org.apache.beam.sdk.transforms.ViewTest > testEmptyIterableSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:470
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:470

org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests > testGroupByKeyAndWindows FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:422
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:422

org.apache.beam.sdk.transforms.join.CoGroupByKeyTest > testCoGroupByKeyWithWindowing FAILED
    java.lang.RuntimeException at CoGroupByKeyTest.java:494
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CoGroupByKeyTest.java:494

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputs FAILED
    java.lang.RuntimeException at ParDoTest.java:810

org.apache.beam.sdk.transforms.CreateTest > testCreate FAILED
    java.lang.RuntimeException at CreateTest.java:90
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CreateTest.java:90

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys10KB FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:353
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:353

org.apache.beam.sdk.testing.PAssertTest > testPAssertEqualsSingletonFalseDefaultReasonString FAILED
    java.lang.AssertionError at PAssertTest.java:386

org.apache.beam.sdk.transforms.FlattenTest > testFlattenInputMultipleCopies FAILED
    java.lang.RuntimeException at FlattenTest.java:162
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:162

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldDescriptorSelectionUnboxing FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:574
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:574

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindows FAILED
    java.lang.RuntimeException at ReshuffleTest.java:251
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ReshuffleTest.java:251

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testOutOfBoundsEventTimeTimer FAILED
    java.lang.RuntimeException at ParDoTest.java:2907
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:2907

org.apache.beam.sdk.transforms.CombineTest$CombineWithContextTests > testSimpleCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:997

org.apache.beam.sdk.transforms.windowing.WindowingTest > testPartitioningWindowing FAILED
    java.lang.RuntimeException at WindowingTest.java:126
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at WindowingTest.java:126

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSessionsCombine FAILED
    java.lang.RuntimeException at CombineTest.java:1267
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1267

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testBagStateSideInput FAILED
    java.lang.RuntimeException at ParDoTest.java:2012
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:2012

org.apache.beam.sdk.transforms.ViewTest > testSideInputWithNestedIterables FAILED
    java.lang.RuntimeException at ViewTest.java:1539
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1539

org.apache.beam.sdk.transforms.SplittableDoFnTest > testPairWithIndexBasicBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:153
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:153

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testCombinePerKeyInstanceMethodReference FAILED
    java.lang.RuntimeException at CombineTest.java:939
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:939

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrder FAILED
    java.lang.RuntimeException at PAssertTest.java:397
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:397

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testSideInputsWithMultipleWindows FAILED
    java.lang.RuntimeException at ParDoTest.java:896
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:896

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKeyWithBadEqualsHashCode FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:347
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:347

org.apache.beam.sdk.transforms.ParDoSchemaTest > testInferredSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:396
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:396

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsEmpty FAILED
    java.lang.RuntimeException at FlattenTest.java:130
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:130

org.apache.beam.sdk.transforms.ReshuffleTest > testReshufflePreservesTimestamps FAILED
    java.lang.RuntimeException at ReshuffleTest.java:148
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ReshuffleTest.java:148

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testEventTimeTimerMultipleKeys FAILED
    java.lang.RuntimeException at ParDoTest.java:2825
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:2825

org.apache.beam.sdk.transforms.CombineTest$CombineWithContextTests > testSimpleCombineWithContextEmpty FAILED
    java.lang.RuntimeException at CombineTest.java:1007
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1007

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testCombiningStateParameterSuperclass FAILED
    java.lang.RuntimeException at ParDoTest.java:1961
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:1961

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testWindowedCombineGloballyAsSingletonView FAILED
    java.lang.RuntimeException at CombineTest.java:1401
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1401

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrderNotSerializable FAILED
    java.lang.RuntimeException at PAssertTest.java:183
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:183

org.apache.beam.sdk.transforms.ViewTest > testListSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:241
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:241

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testBasicCombine FAILED
    java.lang.RuntimeException at CombineTest.java:680
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:680

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys100KB FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:359
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:359

org.apache.beam.sdk.transforms.SplittableDoFnTest > testOutputAfterCheckpointBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:311
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:311

org.apache.beam.sdk.transforms.ParDoSchemaTest > testFieldAccessSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:319
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:319

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindowsAndGroupByKey FAILED
    java.lang.RuntimeException at ReshuffleTest.java:211
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ReshuffleTest.java:211

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoEmptyWithTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:635
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:635

org.apache.beam.sdk.io.CountingSourceTest > testUnboundedSourceSplits FAILED
    java.lang.RuntimeException at CountingSourceTest.java:246

221 tests completed, 129 failed, 2 skipped

> Task :runners:google-cloud-dataflow-java:validatesRunnerLegacyWorkerTest FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesRunnerLegacyWorkerTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Dataflow/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/validatesRunnerLegacyWorkerTest/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 3h 50m 45s
60 actionable tasks: 42 executed, 18 from cache

Publishing build scan...
https://gradle.com/s/3fx7xqsihqtrw

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


Build failed in Jenkins: beam_PostCommit_Java_ValidatesRunner_Dataflow #2950

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

------------------------------------------
[...truncated 59.11 KB...]

org.apache.beam.sdk.transforms.SplittableDoFnTest > testPairWithIndexWindowedTimestampedUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:220
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:220

org.apache.beam.sdk.testing.PAssertTest > testPAssertEqualsSingletonFalseDefaultReasonString FAILED
    java.lang.AssertionError at PAssertTest.java:386

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testCombinePerKeyInstanceMethodReference FAILED
    java.lang.RuntimeException at CombineTest.java:939
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:939

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testMultiOutputParDoWithSideInputsIsCumulative FAILED
    java.lang.RuntimeException at ParDoTest.java:848
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:848

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSessionsCombine FAILED
    java.lang.RuntimeException at CombineTest.java:1267
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1267

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys10KB FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:353
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:353

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testCoderInferenceOfList FAILED
    java.lang.RuntimeException at ParDoTest.java:1568
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:1568

org.apache.beam.sdk.transforms.ParDoSchemaTest > testFieldAccessSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:319
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:319

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testOutOfBoundsEventTimeTimer FAILED
    java.lang.RuntimeException at ParDoTest.java:2907
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:2907

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsSingletonList FAILED
    java.lang.RuntimeException at FlattenTest.java:104
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:104

org.apache.beam.sdk.transforms.ViewTest > testWindowedSideInputFixedToFixedWithDefault FAILED
    java.lang.RuntimeException at ViewTest.java:1455
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1455

org.apache.beam.sdk.transforms.SplittableDoFnTest > testPairWithIndexBasicBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:153
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:153

org.apache.beam.sdk.transforms.ReshuffleTest > testJustReshuffle FAILED
    java.lang.RuntimeException at ReshuffleTest.java:102
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ReshuffleTest.java:102

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrder FAILED
    java.lang.RuntimeException at PAssertTest.java:397
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:397

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testBasicCombine FAILED
    java.lang.RuntimeException at CombineTest.java:680
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:680

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testWindowedCombineGloballyAsSingletonView FAILED
    java.lang.RuntimeException at CombineTest.java:1401
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1401

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithEmptyTaggedOutput FAILED
    java.lang.RuntimeException at ParDoTest.java:659
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:659

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKeyWithBadEqualsHashCode FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:347
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:347

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateDedup FAILED
    java.lang.RuntimeException at ParDoTest.java:1477
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:1477

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testEventTimeTimerMultipleKeys FAILED
    java.lang.RuntimeException at ParDoTest.java:2825
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:2825

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSimpleSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:94
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:94

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputs FAILED
    java.lang.RuntimeException at ParDoTest.java:738
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:738

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollections FAILED
    java.lang.RuntimeException at FlattenTest.java:92
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:92

org.apache.beam.sdk.transforms.SplittableDoFnTest > testOutputAfterCheckpointBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:311
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:311

org.apache.beam.sdk.transforms.ViewTest > testWindowedIterableSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:442
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:442

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrderNotSerializable FAILED
    java.lang.RuntimeException at PAssertTest.java:183
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:183

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testCombineGloballyInstanceMethodReference FAILED
    java.lang.RuntimeException at CombineTest.java:1435
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1435

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testCombinePerKeyLambda FAILED
    java.lang.RuntimeException at CombineTest.java:911
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:911

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys100KB FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:359
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at GroupByKeyTest.java:359

org.apache.beam.sdk.transforms.ParDoTest$StateTests > testValueStateFixedWindows FAILED
    java.lang.RuntimeException at ParDoTest.java:1616
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:1616

org.apache.beam.sdk.transforms.ParDoTest$TimerTests > testPipelineOptionsParameterOnTimer FAILED
    java.lang.RuntimeException at ParDoTest.java:3184
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:3184

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaConversionPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:444
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:444

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithSideInputsIsCumulative FAILED
    java.lang.RuntimeException at ParDoTest.java:772
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoTest.java:772

org.apache.beam.sdk.transforms.FlattenTest > testFlattenMultipleCoders FAILED
    java.lang.RuntimeException at FlattenTest.java:184
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:184

org.apache.beam.sdk.transforms.SplittableDoFnTest > testAdditionalOutputBounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:637
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:637

org.apache.beam.sdk.transforms.ViewTest > testWindowedMapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:1144
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1144

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testFixedWindowsCombine FAILED
    java.lang.RuntimeException at CombineTest.java:1062
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1062

org.apache.beam.sdk.testing.PAssertTest > testSerializablePredicate FAILED
    java.lang.RuntimeException at PAssertTest.java:204
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:204

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testHotKeyCombining FAILED
    java.lang.RuntimeException at CombineTest.java:740
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:740

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteWithSchemaRegistry FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:285
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:285

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsThenParDo FAILED
    java.lang.RuntimeException at FlattenTest.java:118
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:118

org.apache.beam.sdk.transforms.SplittableDoFnTest > testSideInputUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:377
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at SplittableDoFnTest.java:377

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSlidingWindowsCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:1214
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1214

org.apache.beam.sdk.transforms.ViewTest > testWindowedSideInputFixedToGlobal FAILED
    java.lang.RuntimeException at ViewTest.java:1416
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:1416

org.apache.beam.sdk.testing.PAssertTest > testNotEqualTo FAILED
    java.lang.RuntimeException at PAssertTest.java:356
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:356

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testSimpleCombineEmpty FAILED
    java.lang.RuntimeException at CombineTest.java:674
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:674

org.apache.beam.sdk.transforms.FlattenTest > testFlattenMultiplePCollectionsHavingMultipleConsumers FAILED
    java.lang.RuntimeException at FlattenTest.java:347
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at FlattenTest.java:347

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteMultiOutput FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:240
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ParDoSchemaTest.java:240

org.apache.beam.sdk.transforms.ViewTest > testMultimapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:650
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at ViewTest.java:650

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testFixedWindowsCombineWithContext FAILED
    java.lang.RuntimeException at CombineTest.java:1104
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at CombineTest.java:1104

org.apache.beam.sdk.testing.PAssertTest > testGlobalWindowContainsInAnyOrder FAILED
    java.lang.RuntimeException at PAssertTest.java:406
        Caused by: com.google.api.client.googleapis.json.GoogleJsonResponseException at PAssertTest.java:406

org.apache.beam.sdk.testing.PAssertTest > testEmptyFalseDefaultReasonString FAILED
    java.lang.AssertionError at PAssertTest.java:501

org.apache.beam.sdk.transforms.ViewTest > testWindowedSideInputFixedToFixed FAILED
    java.lang.RuntimeException at ViewTest.java:1375

org.apache.beam.sdk.transforms.ViewTest > testEmptyMultimapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:864

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

org.apache.beam.sdk.transforms.ViewTest > testEmptyMapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:1211

org.apache.beam.sdk.transforms.ViewTest > testMultimapAsEntrySetSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:581

221 tests completed, 179 failed, 2 skipped

> Task :runners:google-cloud-dataflow-java:validatesRunnerLegacyWorkerTest FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':runners:google-cloud-dataflow-java:validatesRunnerLegacyWorkerTest'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_ValidatesRunner_Dataflow/ws/src/runners/google-cloud-dataflow-java/build/reports/tests/validatesRunnerLegacyWorkerTest/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 4h 36m 34s
60 actionable tasks: 42 executed, 18 from cache

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

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