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 2021/06/30 16:54:41 UTC

Build failed in Jenkins: beam_PostCommit_Java_VR_Dataflow_V2_Streaming #925

See <https://ci-beam.apache.org/job/beam_PostCommit_Java_VR_Dataflow_V2_Streaming/925/display/redirect>

Changes:


------------------------------------------
[...truncated 86.68 KB...]

org.apache.beam.sdk.transforms.CreateTest > testCreateWithKVVoidType FAILED
    java.lang.RuntimeException at CreateTest.java:341

org.apache.beam.sdk.testing.PAssertTest > testPAssertThatListSatisfiesMultipleMatchersFalse FAILED
    java.lang.AssertionError at PAssertTest.java:741

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWrite FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:168

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoShiftTimestamp FAILED
    java.lang.RuntimeException at ParDoTest.java:1869

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterFixedWindowsAndGroupByKey FAILED
    java.lang.RuntimeException at ReshuffleTest.java:194

org.apache.beam.sdk.transforms.ViewTest > testMapSideInputWithNonDeterministicKeyCoder FAILED
    java.lang.RuntimeException at ViewTest.java:1054

org.apache.beam.sdk.transforms.CreateTest > testCreateWithNullsAndValues FAILED
    java.lang.RuntimeException at CreateTest.java:165

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

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemasPassedThrough FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:438

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoTaggedOutputWithTimestamp FAILED
    java.lang.RuntimeException at ParDoTest.java:1846

org.apache.beam.sdk.transforms.ViewTest > testWindowedSingletonSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:153

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindows FAILED
    java.lang.RuntimeException at ReshuffleTest.java:255

org.apache.beam.sdk.transforms.CreateTest > testCreateWithVoidType FAILED
    java.lang.RuntimeException at CreateTest.java:329

org.apache.beam.sdk.testing.PAssertTest > testWindowedSerializablePredicate FAILED
    java.lang.RuntimeException at PAssertTest.java:244

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldSelectionNested FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:651

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoShiftTimestampUnlimited FAILED
    java.lang.RuntimeException at ParDoTest.java:1958

org.apache.beam.sdk.transforms.ViewTest > testWindowedMultimapSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:741

org.apache.beam.sdk.transforms.ReshuffleTest > testReshufflePreservesTimestamps FAILED
    java.lang.RuntimeException at ReshuffleTest.java:152

org.apache.beam.sdk.transforms.CreateTest > testCreate FAILED
    java.lang.RuntimeException at CreateTest.java:94

org.apache.beam.sdk.testing.PAssertTest > testWindowedIsEqualTo FAILED
    java.lang.RuntimeException at PAssertTest.java:353

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldSelectionUnboxing FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:560

org.apache.beam.sdk.transforms.ViewTest > testSideInputWithNullDefault FAILED
    java.lang.RuntimeException at ViewTest.java:1527

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindowsAndGroupByKey FAILED
    java.lang.RuntimeException at ReshuffleTest.java:215

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoOutputWithTimestamp FAILED
    java.lang.RuntimeException at ParDoTest.java:1811

org.apache.beam.sdk.transforms.ParDoLifecycleTest > testFnCallSequence FAILED
    java.lang.RuntimeException at ParDoLifecycleTest.java:80

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrderFalse FAILED
    java.lang.AssertionError at PAssertTest.java:474

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaFieldDescriptorSelectionUnboxing FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:601

org.apache.beam.sdk.transforms.ViewTest > testWindowedListSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:332

org.apache.beam.sdk.transforms.ReshuffleTest > testJustReshuffle FAILED
    java.lang.RuntimeException at ReshuffleTest.java:106

org.apache.beam.sdk.transforms.ParDoTest$TimerCoderInferenceTests > testValueStateCoderInferenceFromInputCoder FAILED
    java.lang.RuntimeException at ParDoTest.java:4956

org.apache.beam.sdk.transforms.ParDoLifecycleTest > testFnCallSequenceMulti FAILED
    java.lang.RuntimeException at ParDoLifecycleTest.java:93

org.apache.beam.sdk.transforms.KvSwapTest > testKvSwap FAILED
    java.lang.RuntimeException at KvSwapTest.java:80

org.apache.beam.sdk.transforms.ParDoSchemaTest > testInferredSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:423

org.apache.beam.sdk.transforms.ViewTest > testWindowedMapSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:1098

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

org.apache.beam.sdk.transforms.ParDoTest$TimerCoderInferenceTests > testValueStateCoderInference FAILED
    java.lang.RuntimeException at ParDoTest.java:4890

org.apache.beam.sdk.transforms.ParDoLifecycleTest > testFnCallSequenceStateful FAILED
    java.lang.RuntimeException at ParDoLifecycleTest.java:108

org.apache.beam.sdk.transforms.ImpulseTest > testImpulse FAILED
    java.lang.RuntimeException at ImpulseTest.java:47

org.apache.beam.sdk.transforms.ParDoSchemaTest > testFieldAccessSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:345

org.apache.beam.sdk.transforms.ViewTest > testIterableSideInputIsImmutable FAILED
    java.lang.RuntimeException at ViewTest.java:547

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

org.apache.beam.sdk.transforms.GroupByKeyTest > org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests.testGroupByKeyMergingWindows FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:586

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerEndOfWindow FAILED
    java.lang.RuntimeException at WindowTest.java:501

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testGlobalCombineWithDefaultsAndTriggers FAILED
    java.lang.RuntimeException at CombineTest.java:1239

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSimpleSchemaPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:114

org.apache.beam.sdk.transforms.ViewTest > testListSideInputIsImmutable FAILED
    java.lang.RuntimeException at ViewTest.java:410

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

org.apache.beam.sdk.transforms.GroupByKeyTest > org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests.testGroupByKeyMultipleWindows FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:558

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerDefault FAILED
    java.lang.RuntimeException at WindowTest.java:471

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testCombineGloballyLambda FAILED
    java.lang.RuntimeException at CombineTest.java:1421

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemaConversionPipeline FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:471

org.apache.beam.sdk.transforms.ViewTest > testEmptyListSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:361

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

org.apache.beam.sdk.transforms.GroupByKeyTest > org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests.testGroupByKeyAndWindows FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:528

org.apache.beam.sdk.transforms.windowing.WindowTest > testNoWindowFnDoesNotReassignWindows FAILED
    java.lang.RuntimeException at WindowTest.java:437

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testCombineGloballyAsSingletonView FAILED
    java.lang.RuntimeException at CombineTest.java:1356

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteWithSchemaRegistry FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:310

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

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

org.apache.beam.sdk.transforms.GroupByKeyTest > org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests.testTimestampCombinerLatest FAILED
    java.lang.RuntimeException at GroupByKeyTest.java:396

org.apache.beam.sdk.transforms.SplittableDoFnTest > testAdditionalOutputUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:642

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testWindowedCombineEmpty FAILED
    java.lang.RuntimeException at CombineTest.java:1330

org.apache.beam.sdk.transforms.ViewTest > testIterableSideInput FAILED
    java.lang.RuntimeException at ViewTest.java:438

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteMultiOutput FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:265

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

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

org.apache.beam.sdk.transforms.SplittableDoFnTest > testLifecycleMethodsUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:770

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testSlidingWindowsCombine FAILED
    java.lang.RuntimeException at CombineTest.java:1161

org.apache.beam.sdk.transforms.ParDoSchemaTest > testNestedSchema FAILED
    java.lang.RuntimeException at ParDoSchemaTest.java:510

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

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

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

org.apache.beam.sdk.transforms.SplittableDoFnTest > testWindowedSideInputUnbounded FAILED
    java.lang.RuntimeException at SplittableDoFnTest.java:434
FATAL: command execution failed
java.io.IOException: Backing channel 'apache-beam-jenkins-6' is disconnected.
	at hudson.remoting.RemoteInvocationHandler.channelOrFail(RemoteInvocationHandler.java:216)
	at hudson.remoting.RemoteInvocationHandler.invoke(RemoteInvocationHandler.java:286)
	at com.sun.proxy.$Proxy155.isAlive(Unknown Source)
	at hudson.Launcher$RemoteLauncher$ProcImpl.isAlive(Launcher.java:1211)
	at hudson.Launcher$RemoteLauncher$ProcImpl.join(Launcher.java:1203)
	at hudson.Launcher$ProcStarter.join(Launcher.java:523)
	at hudson.plugins.gradle.Gradle.perform(Gradle.java:317)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:804)
	at hudson.model.Build$BuildExecution.build(Build.java:197)
	at hudson.model.Build$BuildExecution.doRun(Build.java:163)
	at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:514)
	at hudson.model.Run.execute(Run.java:1907)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
Caused by: java.io.IOException: Pipe closed after 0 cycles
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:118)
	at org.apache.sshd.common.channel.ChannelPipedInputStream.read(ChannelPipedInputStream.java:101)
	at hudson.remoting.FlightRecorderInputStream.read(FlightRecorderInputStream.java:92)
	at hudson.remoting.ChunkedInputStream.readHeader(ChunkedInputStream.java:73)
	at hudson.remoting.ChunkedInputStream.readUntilBreak(ChunkedInputStream.java:103)
	at hudson.remoting.ChunkedCommandTransport.readBlock(ChunkedCommandTransport.java:39)
	at hudson.remoting.AbstractSynchronousByteArrayCommandTransport.read(AbstractSynchronousByteArrayCommandTransport.java:34)
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:63)
Build step 'Invoke Gradle script' changed build result to FAILURE
Build step 'Invoke Gradle script' marked build as failure
ERROR: apache-beam-jenkins-6 is offline; cannot locate jdk_1.8_latest

---------------------------------------------------------------------
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_VR_Dataflow_V2_Streaming #926

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://ci-beam.apache.org/job/beam_PostCommit_Java_VR_Dataflow_V2_Streaming/926/display/redirect?page=changes>


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