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/12 20:07:12 UTC

Build failed in Jenkins: beam_PostCommit_Java_PVR_Reference #14

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

Changes:

[rohde.samuel] Modify ValidatesRunner to only run a custom test interface for user

[rohde.samuel] Fill in the ProcessBundleDescriptor with correct user timer information

[rohde.samuel] spotless

[rohde.samuel] fix timers to have correct kv coder

[rohde.samuel] Add timers to the ExecutionStage

[rohde.samuel] add initial Dataflow portable user timer implementation

[rohde.samuel] inform the SDK harness of the timers

[rohde.samuel] spotless

[rohde.samuel] clean up comments

[rohde.samuel] remove extra log lines

[rohde.samuel] remote try-catch in receive

[rohde.samuel] change todos to have jira

[rohde.samuel] Add user timer support in ParDoTest.java

[rohde.samuel] spotless

[rohde.samuel] fix merge

[rohde.samuel] remove dev files

[rohde.samuel] undo changes

[rohde.samuel] redundant logic

[rohde.samuel] undo changes?

[rohde.samuel] revert register node function (old unnecessary changes

[rohde.samuel] changes

[rohde.samuel] bad

[rohde.samuel] move fire timers to receive

[rohde.samuel] Update ParDoTest to add more supported timer tests to Dataflow

[rohde.samuel] spotless apply

[rohde.samuel] clean up

[rohde.samuel] finishing touches on user timers

[rohde.samuel] remove logger

[rohde.samuel] remove timer align bounded as supported

[rohde.samuel] remove force experiment

[rohde.samuel] experimental flag isn't in yet, remove supoprt

[rohde.samuel] Refactor timer implementation into its own class

[rohde.samuel] fix imports, and change string to byte encoder for timer test

------------------------------------------
[...truncated 49.95 KB...]

org.apache.beam.sdk.testing.PAssertTest > testContainsInAnyOrderNotSerializable FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at PAssertTest.java:182

org.apache.beam.sdk.testing.PAssertTest > testSerializablePredicate FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at PAssertTest.java:203

org.apache.beam.sdk.testing.PAssertTest > testGlobalWindowContainsInAnyOrder FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at PAssertTest.java:405

org.apache.beam.sdk.values.PCollectionTupleTest > testComposePCollectionTuple FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at PCollectionTupleTest.java:106

org.apache.beam.sdk.transforms.CombineFnsTest > testComposedCombineNullValues FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CombineFnsTest.java:251

org.apache.beam.sdk.transforms.join.CoGroupByKeyTest > testCoGroupByKeyWithWindowing FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CoGroupByKeyTest.java:494

org.apache.beam.sdk.transforms.KeysTest > testKeys FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at KeysTest.java:60

org.apache.beam.sdk.transforms.KeysTest > testKeysEmpty FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at KeysTest.java:73

org.apache.beam.sdk.transforms.KvSwapTest > testKvSwap FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at KvSwapTest.java:77

org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests > testGroupByKeyMergingWindows FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:480

org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests > testGroupByKeyMultipleWindows FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:452

org.apache.beam.sdk.transforms.GroupByKeyTest$WindowTests > testGroupByKeyAndWindows FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:422

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys1MB FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:365

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testTimestampCombinerLatest FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:290

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKeyEmpty FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:145

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testTimestampCombinerEarliest FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:270

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKey FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:128

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys10KB FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:353

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testLargeKeys10MB FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:371

org.apache.beam.sdk.transforms.GroupByKeyTest$BasicTests > testGroupByKeyWithBadEqualsHashCode FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at GroupByKeyTest.java:347

org.apache.beam.sdk.transforms.ImpulseTest > testImpulse FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ImpulseTest.java:47

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSessionsAndGroupByKey FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReshuffleTest.java:169

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterFixedWindows FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReshuffleTest.java:231

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterFixedWindowsAndGroupByKey FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReshuffleTest.java:190

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindows FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReshuffleTest.java:251

org.apache.beam.sdk.transforms.ReshuffleTest > testReshufflePreservesTimestamps FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReshuffleTest.java:148

org.apache.beam.sdk.transforms.ReshuffleTest > testReshuffleAfterSlidingWindowsAndGroupByKey FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReshuffleTest.java:211

org.apache.beam.sdk.transforms.ReshuffleTest > testJustReshuffle FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReshuffleTest.java:102

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testCombinePerKeyLambda FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CombineTest.java:907

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testHotKeyCombining FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CombineTest.java:736

org.apache.beam.sdk.transforms.CombineTest$BasicTests > testHotKeyCombiningWithAccumulationMode FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CombineTest.java:761

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testWindowedCombineEmpty FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CombineTest.java:1300

org.apache.beam.sdk.transforms.CombineTest$WindowingTests > testFixedWindowsCombine FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CombineTest.java:1030

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoShiftTimestamp FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:1303

org.apache.beam.sdk.transforms.ParDoTest$TimestampTests > testParDoShiftTimestampUnlimited FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:1392

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesCollections FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:297

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterablesEmpty FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:312

org.apache.beam.sdk.transforms.FlattenTest > testFlattenInputMultipleCopies FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:162

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsEmpty FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:130

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsSingletonList FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:104

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollections FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:92

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsThenParDo FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:118

org.apache.beam.sdk.transforms.FlattenTest > testFlattenMultiplePCollectionsHavingMultipleConsumers FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:347

org.apache.beam.sdk.transforms.FlattenTest > testFlattenIterables FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:252

org.apache.beam.sdk.transforms.FlattenTest > testFlattenPCollectionsEmptyThenParDo FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at FlattenTest.java:224

org.apache.beam.sdk.transforms.ParDoTest$BasicTests > testParDo FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:346

org.apache.beam.sdk.transforms.ParDoTest$BasicTests > testPipelineOptionsParameter FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:544

org.apache.beam.sdk.transforms.ParDoTest$BasicTests > testParDoEmpty FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:362

org.apache.beam.sdk.transforms.ParDoTest$BasicTests > testParDoInCustomTransform FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:408

org.apache.beam.sdk.transforms.ParDoTest$BasicTests > testParDoEmptyOutputs FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:378

org.apache.beam.sdk.transforms.CreateTest > testCreateEmpty FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CreateTest.java:101

org.apache.beam.sdk.transforms.CreateTest > testCreateWithKVVoidType FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CreateTest.java:337

org.apache.beam.sdk.transforms.CreateTest > testCreateWithNullsAndValues FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CreateTest.java:161

org.apache.beam.sdk.transforms.CreateTest > testCreateWithVoidType FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CreateTest.java:325

org.apache.beam.sdk.transforms.CreateTest > testCreate FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at CreateTest.java:90

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWrite FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoSchemaTest.java:140

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSchemasPassedThrough FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoSchemaTest.java:404

org.apache.beam.sdk.transforms.ParDoSchemaTest > testSimpleSchemaPipeline FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoSchemaTest.java:88

org.apache.beam.sdk.transforms.ParDoSchemaTest > testReadAndWriteWithSchemaRegistry FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoSchemaTest.java:279

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithOnlyTaggedOutput FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:687

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoEmptyWithTaggedOutput FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:634

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithTaggedOutput FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:592

org.apache.beam.sdk.transforms.ParDoTest$MultipleInputsAndOutputTests > testParDoWithEmptyTaggedOutput FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:658

org.apache.beam.sdk.transforms.ParDoTest$LifecycleTests > testWindowingInStartAndFinishBundle FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ParDoTest.java:1220

org.apache.beam.sdk.transforms.windowing.WindowingTest > testMergingWindowing FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WindowingTest.java:168

org.apache.beam.sdk.transforms.windowing.WindowingTest > testNonPartitioningWindowing FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WindowingTest.java:150

org.apache.beam.sdk.transforms.windowing.WindowingTest > testPartitioningWindowing FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WindowingTest.java:126

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerEndOfWindow FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WindowTest.java:498

org.apache.beam.sdk.transforms.windowing.WindowTest > testTimestampCombinerDefault FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WindowTest.java:468

org.apache.beam.sdk.transforms.windowing.WindowTest > testNoWindowFnDoesNotReassignWindows FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WindowTest.java:434

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsShouldApplyTimestamps FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WithTimestampsTest.java:78

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsBackwardsInTimeAndWithAllowedTimestampSkewShouldSucceed FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WithTimestampsTest.java:142

org.apache.beam.sdk.transforms.WithTimestampsTest > withTimestampsLambdaShouldApplyTimestamps FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at WithTimestampsTest.java:205

org.apache.beam.sdk.transforms.ReifyTimestampsTest > extractFromValuesWhenValueTimestampedLaterSucceeds FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReifyTimestampsTest.java:128

org.apache.beam.sdk.transforms.ReifyTimestampsTest > extractFromValuesSucceeds FAILED
    org.apache.beam.vendor.grpc.v1p13p1.io.grpc.StatusRuntimeException at ReifyTimestampsTest.java:92

103 tests completed, 79 failed, 1 skipped

> Task :beam-runners-direct-java:validatesPortableRunner FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':beam-runners-direct-java:validatesPortableRunner'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/beam_PostCommit_Java_PVR_Reference/ws/src/runners/direct-java/build/reports/tests/validatesPortableRunner/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

BUILD FAILED in 18m 34s
72 actionable tasks: 50 executed, 21 from cache, 1 up-to-date

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

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_Reference #15

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


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