You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@kafka.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2019/08/26 13:31:27 UTC

Build failed in Jenkins: kafka-trunk-jdk11 #774

See <https://builds.apache.org/job/kafka-trunk-jdk11/774/display/redirect?page=changes>

Changes:

[gwen] KAFKA-8391; Temporarily ignore flaky Connect rebalance integration tests

[rhauch] MINOR: Fix the doc of scheduled.rebalance.max.delay.ms config property

------------------------------------------
[...truncated 2.26 MB...]
    java.lang.AssertionError: 
    Expected: <KeyValue(start, 1566823721666)>
         but: was null
        at org.hamcrest.MatcherAssert.assertThat(MatcherAssert.java:18)
        at org.hamcrest.MatcherAssert.assertThat(MatcherAssert.java:6)
        at org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest.shouldReduceSessionWindows(KStreamAggregationIntegrationTest.java:667)

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountWithInternalStore STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountWithInternalStore PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountUnlimitedWindows STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountUnlimitedWindows PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountSessionWindows STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountSessionWindows PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed PASSED

org.apache.kafka.streams.integration.SmokeTestDriverIntegrationTest > shouldWorkWithRebalance STARTED
org.apache.kafka.streams.integration.SmokeTestDriverIntegrationTest.shouldWorkWithRebalance failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.SmokeTestDriverIntegrationTest.shouldWorkWithRebalance.test.stdout>

org.apache.kafka.streams.integration.SmokeTestDriverIntegrationTest > shouldWorkWithRebalance FAILED
    java.lang.AssertionError: verifying tagg
    fail: key=694 tagg=[ConsumerRecord(topic = tagg, partition = 0, leaderEpoch = 0, offset = 5, CreateTime = 1566824033327, serialized key size = 3, serialized value size = 8, headers = RecordHeaders(headers = [], isReadOnly = false), key = 694, value = 2)] expected=null
    	 outputEvents: [ConsumerRecord(topic = tagg, partition = 0, leaderEpoch = 0, offset = 5, CreateTime = 1566824033327, serialized key size = 3, serialized value size = 8, headers = RecordHeaders(headers = [], isReadOnly = false), key = 694, value = 2)]
    verifying suppressed min-suppressed
    verifying min-suppressed with 10 keys
    verifying suppressed sws-suppressed
    verifying min with 10 keys
    verifying max with 10 keys
    verifying dif with 10 keys
    verifying sum with 10 keys
    verifying cnt with 10 keys
    verifying avg with 10 keys
        at org.junit.Assert.fail(Assert.java:89)
        at org.junit.Assert.assertTrue(Assert.java:42)
        at org.apache.kafka.streams.integration.SmokeTestDriverIntegrationTest.shouldWorkWithRebalance(SmokeTestDriverIntegrationTest.java:137)

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduce STARTED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduce PASSED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldGroupByKey STARTED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldGroupByKey PASSED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduceWindowed STARTED

org.apache.kafka.streams.integration.KStreamAggregationDedupIntegrationTest > shouldReduceWindowed PASSED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[0: eosEnabled=false] STARTED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[0: eosEnabled=false] PASSED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[1: eosEnabled=true] STARTED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[1: eosEnabled=true] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftInner[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftInner[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftInner[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftInner[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftInner(TableTableJoinIntegrationTest.java:338)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftOuter[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftOuter[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftOuter[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftOuter[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftOuter(TableTableJoinIntegrationTest.java:432)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftLeft[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftLeft[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftLeft[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftLeft[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeftLeft(TableTableJoinIntegrationTest.java:383)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterLeft[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterLeft[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterLeft[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterLeft[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterLeft(TableTableJoinIntegrationTest.java:529)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInner[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInner[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInner[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInner[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInner(TableTableJoinIntegrationTest.java:100)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuter[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuter[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuter[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuter[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuter(TableTableJoinIntegrationTest.java:162)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeft[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeft[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeft[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeft[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testLeft(TableTableJoinIntegrationTest.java:131)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerInner[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerInner[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerInner[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerInner[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerInner(TableTableJoinIntegrationTest.java:197)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerOuter[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerOuter[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerOuter[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerOuter[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerOuter(TableTableJoinIntegrationTest.java:289)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerLeft[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerLeft[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerLeft[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerLeft[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testInnerLeft(TableTableJoinIntegrationTest.java:244)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterInner[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterInner[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterInner[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterInner[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterInner(TableTableJoinIntegrationTest.java:482)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterOuter[caching enabled = true] STARTED
org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterOuter[caching enabled = true] failed, log available in <https://builds.apache.org/job/kafka-trunk-jdk11/ws/streams/build/reports/testOutput/org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterOuter[caching> enabled = true].test.stdout

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterOuter[caching enabled = true] FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Never received expected final result.
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:376)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:336)
        at org.apache.kafka.streams.integration.AbstractJoinIntegrationTest.runTest(AbstractJoinIntegrationTest.java:255)
        at org.apache.kafka.streams.integration.TableTableJoinIntegrationTest.testOuterOuter(TableTableJoinIntegrationTest.java:580)

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftInner[caching enabled = false] STARTED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftInner[caching enabled = false] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftOuter[caching enabled = false] STARTED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftOuter[caching enabled = false] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftLeft[caching enabled = false] STARTED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeftLeft[caching enabled = false] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterLeft[caching enabled = false] STARTED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuterLeft[caching enabled = false] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInner[caching enabled = false] STARTED
ERROR: No tool found matching GRADLE_4_10_2_HOME
ERROR: Could not install GRADLE_4_10_3_HOME
java.lang.NullPointerException

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInner[caching enabled = false] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuter[caching enabled = false] STARTED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testOuter[caching enabled = false] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeft[caching enabled = false] STARTED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testLeft[caching enabled = false] PASSED

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerInner[caching enabled = false] STARTED
Build timed out (after 480 minutes). Marking the build as failed.
Build was aborted
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3

org.apache.kafka.streams.integration.TableTableJoinIntegrationTest > testInnerInner[caching enabled = false] SKIPPED

111 tests completed, 18 failed, 1 skipped
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user wangguoz@gmail.com
Not sending mail to unregistered user gwen@confluent.io

Jenkins build is back to normal : kafka-trunk-jdk11 #777

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk11/777/display/redirect?page=changes>


Build failed in Jenkins: kafka-trunk-jdk11 #776

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk11/776/display/redirect?page=changes>

Changes:

[wangguoz] KAFKA-8816: Make offsets immutable to users of RecordCollector.offsets

------------------------------------------
[...truncated 2.61 MB...]
org.apache.kafka.streams.integration.SuppressionIntegrationTest > shouldShutdownWhenBytesConstraintIsViolated STARTED

org.apache.kafka.streams.integration.SuppressionIntegrationTest > shouldShutdownWhenBytesConstraintIsViolated PASSED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldKStreamGlobalKTableLeftJoin STARTED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldKStreamGlobalKTableLeftJoin PASSED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldNotRestoreAbortedMessages STARTED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldNotRestoreAbortedMessages PASSED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldRestoreTransactionalMessages STARTED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldRestoreTransactionalMessages PASSED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldKStreamGlobalKTableJoin STARTED

org.apache.kafka.streams.integration.GlobalKTableEOSIntegrationTest > shouldKStreamGlobalKTableJoin PASSED

org.apache.kafka.streams.integration.StandbyTaskCreationIntegrationTest > shouldNotCreateAnyStandByTasksForStateStoreWithLoggingDisabled STARTED

org.apache.kafka.streams.integration.StandbyTaskCreationIntegrationTest > shouldNotCreateAnyStandByTasksForStateStoreWithLoggingDisabled PASSED

org.apache.kafka.streams.integration.StandbyTaskCreationIntegrationTest > shouldCreateStandByTasksForMaterializedAndOptimizedSourceTables STARTED

org.apache.kafka.streams.integration.StandbyTaskCreationIntegrationTest > shouldCreateStandByTasksForMaterializedAndOptimizedSourceTables PASSED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldOnlyReadRecordsWhereEarliestSpecifiedWithNoCommittedOffsetsWithGlobalAutoOffsetResetLatest STARTED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldOnlyReadRecordsWhereEarliestSpecifiedWithNoCommittedOffsetsWithGlobalAutoOffsetResetLatest PASSED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldThrowExceptionOverlappingPattern STARTED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldThrowExceptionOverlappingPattern PASSED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldThrowExceptionOverlappingTopic STARTED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldThrowExceptionOverlappingTopic PASSED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldOnlyReadRecordsWhereEarliestSpecifiedWithInvalidCommittedOffsets STARTED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldOnlyReadRecordsWhereEarliestSpecifiedWithInvalidCommittedOffsets PASSED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldOnlyReadRecordsWhereEarliestSpecifiedWithNoCommittedOffsetsWithDefaultGlobalAutoOffsetResetEarliest STARTED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldOnlyReadRecordsWhereEarliestSpecifiedWithNoCommittedOffsetsWithDefaultGlobalAutoOffsetResetEarliest PASSED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldThrowStreamsExceptionNoResetSpecified STARTED

org.apache.kafka.streams.integration.FineGrainedAutoResetIntegrationTest > shouldThrowStreamsExceptionNoResetSpecified PASSED

org.apache.kafka.streams.integration.GlobalThreadShutDownOrderTest > shouldFinishGlobalStoreOperationOnShutDown STARTED

org.apache.kafka.streams.integration.GlobalThreadShutDownOrderTest > shouldFinishGlobalStoreOperationOnShutDown PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > shouldNotAllowToResetWhenInputTopicAbsent STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > shouldNotAllowToResetWhenInputTopicAbsent PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > shouldNotAllowToResetWhenIntermediateTopicAbsent STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > shouldNotAllowToResetWhenIntermediateTopicAbsent PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingByDurationAfterResetWithoutIntermediateUserTopic STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingByDurationAfterResetWithoutIntermediateUserTopic PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithIntermediateUserTopic PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromScratchAfterResetWithoutIntermediateUserTopic PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromFileAfterResetWithoutIntermediateUserTopic STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromFileAfterResetWithoutIntermediateUserTopic PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromDateTimeAfterResetWithoutIntermediateUserTopic STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > testReprocessingFromDateTimeAfterResetWithoutIntermediateUserTopic PASSED

org.apache.kafka.streams.integration.ResetIntegrationTest > shouldNotAllowToResetWhileStreamsRunning STARTED

org.apache.kafka.streams.integration.ResetIntegrationTest > shouldNotAllowToResetWhileStreamsRunning PASSED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldProcessDataFromStoresWithLoggingDisabled STARTED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldProcessDataFromStoresWithLoggingDisabled PASSED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldRestoreStateFromSourceTopic STARTED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldRestoreStateFromSourceTopic PASSED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldSuccessfullyStartWhenLoggingDisabled STARTED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldSuccessfullyStartWhenLoggingDisabled PASSED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldRestoreStateFromChangelogTopic STARTED

org.apache.kafka.streams.integration.RestoreIntegrationTest > shouldRestoreStateFromChangelogTopic PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRunWithEosEnabled STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRunWithEosEnabled PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToCommitToMultiplePartitions STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToCommitToMultiplePartitions PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldNotViolateEosIfOneTaskFails STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldNotViolateEosIfOneTaskFails PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToPerformMultipleTransactions STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToPerformMultipleTransactions PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToCommitMultiplePartitionOffsets STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToCommitMultiplePartitionOffsets PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRunWithTwoSubtopologies STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRunWithTwoSubtopologies PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldNotViolateEosIfOneTaskGetsFencedUsingIsolatedAppInstances STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldNotViolateEosIfOneTaskGetsFencedUsingIsolatedAppInstances PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldNotViolateEosIfOneTaskFailsWithState STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldNotViolateEosIfOneTaskFailsWithState PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRunWithTwoSubtopologiesAndMultiplePartitions STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRunWithTwoSubtopologiesAndMultiplePartitions PASSED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRestartAfterClose STARTED

org.apache.kafka.streams.integration.EosIntegrationTest > shouldBeAbleToRestartAfterClose PASSED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[0: eosEnabled=false] STARTED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[0: eosEnabled=false] PASSED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[1: eosEnabled=true] STARTED

org.apache.kafka.streams.integration.SuppressionDurabilityIntegrationTest > shouldRecoverBufferAfterShutdown[1: eosEnabled=true] PASSED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigrateInMemoryKeyValueStoreToTimestampedKeyValueStoreUsingPapi STARTED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigrateInMemoryKeyValueStoreToTimestampedKeyValueStoreUsingPapi PASSED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldProxyWindowStoreToTimestampedWindowStoreUsingPapi STARTED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldProxyWindowStoreToTimestampedWindowStoreUsingPapi PASSED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigratePersistentKeyValueStoreToTimestampedKeyValueStoreUsingPapi STARTED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigratePersistentKeyValueStoreToTimestampedKeyValueStoreUsingPapi PASSED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigratePersistentWindowStoreToTimestampedWindowStoreUsingPapi STARTED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigratePersistentWindowStoreToTimestampedWindowStoreUsingPapi PASSED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldProxyKeyValueStoreToTimestampedKeyValueStoreUsingPapi STARTED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldProxyKeyValueStoreToTimestampedKeyValueStoreUsingPapi PASSED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigrateInMemoryWindowStoreToTimestampedWindowStoreUsingPapi STARTED

org.apache.kafka.streams.integration.StoreUpgradeIntegrationTest > shouldMigrateInMemoryWindowStoreToTimestampedWindowStoreUsingPapi PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceSessionWindows STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceSessionWindows PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduce PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregate PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCount PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldGroupByKey PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountWithInternalStore STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountWithInternalStore PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountUnlimitedWindows STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountUnlimitedWindows PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldReduceWindowed PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountSessionWindows STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldCountSessionWindows PASSED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed STARTED

org.apache.kafka.streams.integration.KStreamAggregationIntegrationTest > shouldAggregateWindowed PASSED

org.apache.kafka.streams.KeyValueTest > shouldHaveSameEqualsAndHashCode STARTED

org.apache.kafka.streams.KeyValueTest > shouldHaveSameEqualsAndHashCode PASSED
streams-1: SMOKE-TEST-CLIENT-CLOSED
streams-2: SMOKE-TEST-CLIENT-CLOSED
streams-0: SMOKE-TEST-CLIENT-CLOSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/build/reports/tests/test/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.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5h 13m 40s
182 actionable tasks: 155 executed, 27 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-trunk-jdk11 #775

Posted by Apache Jenkins Server <je...@builds.apache.org>.
See <https://builds.apache.org/job/kafka-trunk-jdk11/775/display/redirect?page=changes>

Changes:

[wangguoz] KAFKA-8412: Fix nullpointer exception thrown on flushing before closing

[harsha] KAFKA-8669: Add security providers in kafka security config (#7090)

------------------------------------------
[...truncated 2.60 MB...]

org.apache.kafka.connect.transforms.RegexRouterTest > staticReplacement STARTED

org.apache.kafka.connect.transforms.RegexRouterTest > staticReplacement PASSED

org.apache.kafka.connect.transforms.ReplaceFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.ReplaceFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.ReplaceFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.ReplaceFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdateWithStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdateWithStruct PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfStruct PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaNameAndVersionUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNull STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNull PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaVersionUpdate STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > schemaVersionUpdate PASSED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNonStruct STARTED

org.apache.kafka.connect.transforms.SetSchemaMetadataTest > updateSchemaOfNonStruct PASSED

org.apache.kafka.connect.transforms.HoistFieldTest > withSchema STARTED

org.apache.kafka.connect.transforms.HoistFieldTest > withSchema PASSED

org.apache.kafka.connect.transforms.HoistFieldTest > schemaless STARTED

org.apache.kafka.connect.transforms.HoistFieldTest > schemaless PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessFieldConversion STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessFieldConversion PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidTargetType STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidTargetType PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessStringToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessStringToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testKey STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testKey PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessDateToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullValueToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaFieldConversion PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaDateToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaIdentity PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessTimestampToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigMissingFormat PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessNullValueToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToDate STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToDate PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTime STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToTime PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToUnix STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaNullFieldToUnix PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigNoTargetType PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaStringToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimeToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testSchemalessUnixToTimestamp PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testWithSchemaTimestampToString PASSED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat STARTED

org.apache.kafka.connect.transforms.TimestampConverterTest > testConfigInvalidFormat PASSED

org.apache.kafka.connect.transforms.ValueToKeyTest > withSchema STARTED

org.apache.kafka.connect.transforms.ValueToKeyTest > withSchema PASSED

org.apache.kafka.connect.transforms.ValueToKeyTest > schemaless STARTED

org.apache.kafka.connect.transforms.ValueToKeyTest > schemaless PASSED

> Task :streams:examples:test

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test STARTED

org.apache.kafka.streams.examples.wordcount.WordCountProcessorTest > test PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/build/reports/tests/test/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.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 3h 8m 13s
182 actionable tasks: 155 executed, 27 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
ERROR: No tool found matching GRADLE_4_10_2_HOME
Setting GRADLE_4_10_3_HOME=/home/jenkins/tools/gradle/4.10.3
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user noreply@github.com
Not sending mail to unregistered user wangguoz@gmail.com