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 2017/10/05 01:36:51 UTC

Build failed in Jenkins: kafka-trunk-jdk7 #2855

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

Changes:

[junrao] KAFKA-5767; Kafka server should halt if IBP < 1.0.0 and there is log

------------------------------------------
[...truncated 1.81 MB...]

org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > shouldOuterOuterJoinQueryable STARTED

org.apache.kafka.streams.integration.KTableKTableJoinIntegrationTest > shouldOuterOuterJoinQueryable PASSED

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

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

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

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

org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput STARTED

org.apache.kafka.streams.integration.FanoutIntegrationTest > shouldFanoutTheInput 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.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperationsWithZeroSizedCache STARTED

org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperationsWithZeroSizedCache PASSED

org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperationsWithNonZeroSizedCache STARTED

org.apache.kafka.streams.integration.KStreamRepartitionJoinTest > shouldCorrectlyRepartitionOnJoinOperationsWithNonZeroSizedCache PASSED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegionWithZeroByteCache STARTED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegionWithZeroByteCache PASSED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegionWithNonZeroByteCache STARTED

org.apache.kafka.streams.integration.KStreamKTableJoinIntegrationTest > shouldCountClicksPerRegionWithNonZeroByteCache PASSED

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldCompactTopicsForStateChangelogs STARTED

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldCompactTopicsForStateChangelogs PASSED

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldUseCompactAndDeleteForWindowStoreChangelogs STARTED

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldUseCompactAndDeleteForWindowStoreChangelogs 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 > 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.KStreamsFineGrainedAutoResetIntegrationTest > shouldOnlyReadRecordsWhereEarliestSpecifiedWithNoCommittedOffsetsWithGlobalAutoOffsetResetLatest STARTED

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

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

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

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

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

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

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

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

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

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

org.apache.kafka.streams.integration.KStreamsFineGrainedAutoResetIntegrationTest > shouldThrowStreamsExceptionNoResetSpecified PASSED
:log4j-appender:jar
:tools:compileJava
:tools:processResources NO-SOURCE
:tools:classes
:tools:checkstyleMain
:tools:compileTestJava
:tools:processTestResources
:tools:testClasses
:tools:checkstyleTest
:tools:findbugsMain
:tools:test

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCreateFault STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCreateFault PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testNetworkPartitionFault STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testNetworkPartitionFault PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testFaultDistribution STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testFaultDistribution PASSED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCoordinatorStatus STARTED

org.apache.kafka.trogdor.coordinator.CoordinatorTest > testCoordinatorStatus PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentActivatesFaults STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentActivatesFaults FAILED
    java.lang.AssertionError: Condition not met within timeout 15000. Timed out waiting for expected fault specs {bar: {state: {"stateName":"done","doneMs":7,"errorStr":""}}, baz: {state: {"stateName":"running","startedMs":7}}, foo: {state: {"stateName":"done","doneMs":3,"errorStr":""}}}
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:276)
        at org.apache.kafka.test.TestUtils.waitForCondition(TestUtils.java:254)
        at org.apache.kafka.trogdor.common.ExpectedFaults.waitFor(ExpectedFaults.java:119)
        at org.apache.kafka.trogdor.common.ExpectedFaults.waitFor(ExpectedFaults.java:109)
        at org.apache.kafka.trogdor.agent.AgentTest.testAgentActivatesFaults(AgentTest.java:148)

org.apache.kafka.trogdor.agent.AgentTest > testAgentGetStatus STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentGetStatus PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentStartShutdown STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentStartShutdown PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentCreateFaults STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentCreateFaults PASSED

org.apache.kafka.trogdor.agent.AgentTest > testAgentProgrammaticShutdown STARTED

org.apache.kafka.trogdor.agent.AgentTest > testAgentProgrammaticShutdown PASSED

org.apache.kafka.trogdor.fault.FaultSetTest > testIterateByStart STARTED

org.apache.kafka.trogdor.fault.FaultSetTest > testIterateByStart PASSED

org.apache.kafka.trogdor.fault.FaultSetTest > testDeletes STARTED

org.apache.kafka.trogdor.fault.FaultSetTest > testDeletes PASSED

org.apache.kafka.trogdor.fault.FaultSetTest > testIterateByEnd STARTED

org.apache.kafka.trogdor.fault.FaultSetTest > testIterateByEnd PASSED

org.apache.kafka.trogdor.fault.FaultSetTest > testEqualRanges STARTED

org.apache.kafka.trogdor.fault.FaultSetTest > testEqualRanges PASSED

org.apache.kafka.trogdor.basic.BasicPlatformTest > testCreateBasicPlatform STARTED

org.apache.kafka.trogdor.basic.BasicPlatformTest > testCreateBasicPlatform PASSED

14 tests completed, 1 failed
:tools:test FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':tools:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-trunk-jdk7/ws/tools/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.

* Get more help at https://help.gradle.org

BUILD FAILED in 1h 22m 58s
60 actionable tasks: 50 executed, 10 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-jdk7/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 6 files in <https://builds.apache.org/job/kafka-trunk-jdk7/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk7/ws/clients/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk7/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk7/ws/examples/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk7/ws/log4j-appender/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk7/ws/streams/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk7/ws/tools/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=20d9adb173a0cde010a2502da7415ecda9bcaa80, workspace=<https://builds.apache.org/job/kafka-trunk-jdk7/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2854
Recording test results
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2

Jenkins build is back to normal : kafka-trunk-jdk7 #2856

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