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 2018/04/03 21:06:42 UTC

Build failed in Jenkins: kafka-trunk-jdk8 #2522

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

Changes:

[me] MINOR: Make kafka-streams-test-utils dependencies work with releases

[me] KAFKA-6728: Corrected the worker’s instantiation of the HeaderConverter

[wangguoz] MINOR: Refactor return value (#4810)

------------------------------------------
[...truncated 3.95 MB...]

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfInitializerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfMaterializedIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfMaterializedIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfMergerIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfMergerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeCount STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeCount PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeWithoutSpecifyingSerdes STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeWithoutSpecifyingSerdes PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeAggregated STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeAggregated PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnCountIfMaterializedIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnCountIfMaterializedIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfAggregatorIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfAggregatorIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnReduceIfReducerIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnReduceIfReducerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldAggregateSessionWindowed STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldAggregateSessionWindowed PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldCountSessionWindowed STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldCountSessionWindowed PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldReduceWindowed STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldReduceWindowed PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfAggregatorIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedAggregateIfAggregatorIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfInitializerIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfInitializerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfMergerIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnAggregateIfMergerIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedReduceIfMaterializedIsNull STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldThrowNullPointerOnMaterializedReduceIfMaterializedIsNull PASSED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeReduced STARTED

org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImplTest > shouldMaterializeReduced PASSED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldClearGlobalTableEntryOnNullValueUpdates STARTED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldClearGlobalTableEntryOnNullValueUpdates PASSED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldJoinRegardlessIfMatchFoundOnStreamUpdates STARTED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldJoinRegardlessIfMatchFoundOnStreamUpdates PASSED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldNotJoinWithEmptyGlobalTableOnStreamUpdates STARTED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldNotJoinWithEmptyGlobalTableOnStreamUpdates PASSED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldNotJoinOnGlobalTableUpdates STARTED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldNotJoinOnGlobalTableUpdates PASSED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldNotRequireCopartitioning STARTED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldNotRequireCopartitioning PASSED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldJoinOnNullKeyMapperValues STARTED

org.apache.kafka.streams.kstream.internals.KStreamGlobalKTableLeftJoinTest > shouldJoinOnNullKeyMapperValues PASSED

org.apache.kafka.streams.kstream.internals.KStreamSelectKeyTest > testSelectKey STARTED

org.apache.kafka.streams.kstream.internals.KStreamSelectKeyTest > testSelectKey PASSED

org.apache.kafka.streams.kstream.internals.KStreamSelectKeyTest > testTypeVariance STARTED

org.apache.kafka.streams.kstream.internals.KStreamSelectKeyTest > testTypeVariance PASSED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testMap STARTED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testMap PASSED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testTypeVariance STARTED

org.apache.kafka.streams.kstream.internals.KStreamMapTest > testTypeVariance PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddRegexTopicToLatestAutoOffsetResetList STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddRegexTopicToLatestAutoOffsetResetList PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldMapStateStoresToCorrectSourceTopics STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldMapStateStoresToCorrectSourceTopics PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTableToEarliestAutoOffsetResetList STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTableToEarliestAutoOffsetResetList PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldHaveNullTimestampExtractorWhenNoneSupplied STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldHaveNullTimestampExtractorWhenNoneSupplied PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildGlobalTopologyWithAllGlobalTables STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildGlobalTopologyWithAllGlobalTables PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddRegexTopicToEarliestAutoOffsetResetList STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddRegexTopicToEarliestAutoOffsetResetList PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTopicToEarliestAutoOffsetResetList STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTopicToEarliestAutoOffsetResetList PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldHaveCorrectSourceTopicsForTableFromMergedStream STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldHaveCorrectSourceTopicsForTableFromMergedStream PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > testNewStoreName STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > testNewStoreName PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTopicToLatestAutoOffsetResetList STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTopicToLatestAutoOffsetResetList PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildSimpleGlobalTableTopology STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildSimpleGlobalTableTopology PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTableToLatestAutoOffsetResetList STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddTableToLatestAutoOffsetResetList PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldNotAddTableToOffsetResetLists STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldNotAddTableToOffsetResetLists PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddGlobalTablesToEachGroup STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldAddGlobalTablesToEachGroup PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildGlobalTableWithNonQueryableStoreName STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildGlobalTableWithNonQueryableStoreName PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldNotAddRegexTopicsToOffsetResetLists STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldNotAddRegexTopicsToOffsetResetLists PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildGlobalTableWithQueryaIbleStoreName STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldBuildGlobalTableWithQueryaIbleStoreName PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > ktableShouldHaveNullTimestampExtractorWhenNoneSupplied STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > ktableShouldHaveNullTimestampExtractorWhenNoneSupplied PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > testNewName STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > testNewName PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > ktableShouldUseProvidedTimestampExtractor STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > ktableShouldUseProvidedTimestampExtractor PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldStillMaterializeSourceKTableIfMaterializedIsntQueryable STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldStillMaterializeSourceKTableIfMaterializedIsntQueryable PASSED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldUseProvidedTimestampExtractor STARTED

org.apache.kafka.streams.kstream.internals.InternalStreamsBuilderTest > shouldUseProvidedTimestampExtractor PASSED

org.apache.kafka.streams.kstream.WindowsTest > retentionTimeMustNotBeNegative STARTED

org.apache.kafka.streams.kstream.WindowsTest > retentionTimeMustNotBeNegative PASSED

org.apache.kafka.streams.kstream.WindowsTest > numberOfSegmentsMustBeAtLeastTwo STARTED

org.apache.kafka.streams.kstream.WindowsTest > numberOfSegmentsMustBeAtLeastTwo PASSED

org.apache.kafka.streams.kstream.WindowsTest > shouldSetWindowRetentionTime STARTED

org.apache.kafka.streams.kstream.WindowsTest > shouldSetWindowRetentionTime PASSED

org.apache.kafka.streams.kstream.WindowsTest > shouldSetNumberOfSegments STARTED

org.apache.kafka.streams.kstream.WindowsTest > shouldSetNumberOfSegments PASSED

1900 tests completed, 1 failed
:streams:test FAILED

FAILURE: Build failed with an exception.

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

BUILD FAILED in 1h 45m 24s
62 actionable tasks: 59 executed, 3 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 6 files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/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-jdk8/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-jdk8/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-jdk8/ws/jmh-benchmarks/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/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-jdk8/ws/streams/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=1815e01188e1f1f7c71acc9fb6466dbae8e47c9e, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2519
Recording test results
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user wangguoz@gmail.com
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk

Jenkins build is back to normal : kafka-trunk-jdk8 #2524

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


Build failed in Jenkins: kafka-trunk-jdk8 #2523

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

Changes:

[jason] KAFKA-6739; Ignore headers when down-converting from V2 to V0/V1 (#4813)

------------------------------------------
[...truncated 422.24 KB...]

kafka.controller.ReplicaStateMachineTest > testInvalidOfflineReplicaToReplicaDeletionIneligibleTransition PASSED

kafka.controller.ReplicaStateMachineTest > testNewReplicaToOfflineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testNewReplicaToOfflineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToOnlineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToReplicaDeletionStartedTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToReplicaDeletionStartedTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToReplicaDeletionSuccessfulTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToReplicaDeletionSuccessfulTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidOfflineReplicaToNonexistentReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidOfflineReplicaToNonexistentReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToReplicaDeletionIneligibleTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToReplicaDeletionIneligibleTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToReplicaDeletionStartedTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToReplicaDeletionStartedTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidNewReplicaToReplicaDeletionSuccessfulTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNewReplicaToReplicaDeletionSuccessfulTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionIneligibleToReplicaDeletionStartedTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionIneligibleToReplicaDeletionStartedTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionStartedToOfflineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionStartedToOfflineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidNewReplicaToReplicaDeletionStartedTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNewReplicaToReplicaDeletionStartedTransition PASSED

kafka.controller.ReplicaStateMachineTest > testOnlineReplicaToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testOnlineReplicaToOnlineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidNewReplicaToReplicaDeletionIneligibleTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNewReplicaToReplicaDeletionIneligibleTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOfflineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOfflineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionSuccessfulTransition STARTED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionSuccessfulTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOnlineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToNewReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToNewReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionIneligibleTransition STARTED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionIneligibleTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToOfflineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToOfflineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionIneligibleToNewReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionIneligibleToNewReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionIneligibleToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionIneligibleToOnlineReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionStartedToNewReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionStartedToNewReplicaTransition PASSED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToReplicaDeletionSuccessfulTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToReplicaDeletionSuccessfulTransition PASSED

kafka.controller.ReplicaStateMachineTest > testNewReplicaToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testNewReplicaToOnlineReplicaTransition PASSED

kafka.controller.ControllerIntegrationTest > testPartitionReassignmentWithOfflineReplicaHaltingProgress STARTED

kafka.controller.ControllerIntegrationTest > testPartitionReassignmentWithOfflineReplicaHaltingProgress PASSED

kafka.controller.ControllerIntegrationTest > testControllerEpochPersistsWhenAllBrokersDown STARTED

kafka.controller.ControllerIntegrationTest > testControllerEpochPersistsWhenAllBrokersDown PASSED

kafka.controller.ControllerIntegrationTest > testTopicCreationWithOfflineReplica STARTED

kafka.controller.ControllerIntegrationTest > testTopicCreationWithOfflineReplica PASSED

kafka.controller.ControllerIntegrationTest > testPartitionReassignmentResumesAfterReplicaComesOnline STARTED

kafka.controller.ControllerIntegrationTest > testPartitionReassignmentResumesAfterReplicaComesOnline PASSED

kafka.controller.ControllerIntegrationTest > testLeaderAndIsrWhenEntireIsrOfflineAndUncleanLeaderElectionDisabled STARTED

kafka.controller.ControllerIntegrationTest > testLeaderAndIsrWhenEntireIsrOfflineAndUncleanLeaderElectionDisabled PASSED

kafka.controller.ControllerIntegrationTest > testTopicPartitionExpansionWithOfflineReplica STARTED

kafka.controller.ControllerIntegrationTest > testTopicPartitionExpansionWithOfflineReplica PASSED

kafka.controller.ControllerIntegrationTest > testPreferredReplicaLeaderElectionWithOfflinePreferredReplica STARTED

kafka.controller.ControllerIntegrationTest > testPreferredReplicaLeaderElectionWithOfflinePreferredReplica PASSED

kafka.controller.ControllerIntegrationTest > testAutoPreferredReplicaLeaderElection STARTED

kafka.controller.ControllerIntegrationTest > testAutoPreferredReplicaLeaderElection PASSED

kafka.controller.ControllerIntegrationTest > testTopicCreation STARTED

kafka.controller.ControllerIntegrationTest > testTopicCreation PASSED

kafka.controller.ControllerIntegrationTest > testPartitionReassignment STARTED

kafka.controller.ControllerIntegrationTest > testPartitionReassignment PASSED

kafka.controller.ControllerIntegrationTest > testTopicPartitionExpansion STARTED

kafka.controller.ControllerIntegrationTest > testTopicPartitionExpansion PASSED

kafka.controller.ControllerIntegrationTest > testControllerMoveIncrementsControllerEpoch STARTED

kafka.controller.ControllerIntegrationTest > testControllerMoveIncrementsControllerEpoch PASSED

kafka.controller.ControllerIntegrationTest > testLeaderAndIsrWhenEntireIsrOfflineAndUncleanLeaderElectionEnabled STARTED

kafka.controller.ControllerIntegrationTest > testLeaderAndIsrWhenEntireIsrOfflineAndUncleanLeaderElectionEnabled PASSED

kafka.controller.ControllerIntegrationTest > testBackToBackPreferredReplicaLeaderElections STARTED

kafka.controller.ControllerIntegrationTest > testBackToBackPreferredReplicaLeaderElections PASSED

kafka.controller.ControllerIntegrationTest > testEmptyCluster STARTED

kafka.controller.ControllerIntegrationTest > testEmptyCluster PASSED

kafka.controller.ControllerIntegrationTest > testPreferredReplicaLeaderElection STARTED

kafka.controller.ControllerIntegrationTest > testPreferredReplicaLeaderElection PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdInvalidGroupId STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdInvalidGroupId PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteNonEmptyGroup STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteNonEmptyGroup PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdWithMixOfSuccessAndError STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdWithMixOfSuccessAndError PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteWithShortInitialization STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteWithShortInitialization PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdWithShortInitialization STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdWithShortInitialization PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteWithTopicOption STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteWithTopicOption PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteNonExistingGroup STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteNonExistingGroup PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdNonEmptyGroup STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdNonEmptyGroup PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdNonExistingGroup STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdNonExistingGroup PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteEmptyGroup STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteEmptyGroup PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteWithMixOfSuccessAndError STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteWithMixOfSuccessAndError PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdEmptyGroup STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteCmdEmptyGroup PASSED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteInvalidGroupId STARTED

unit.kafka.admin.DeleteConsumerGroupTest > testDeleteInvalidGroupId PASSED

1912 tests completed, 1 failed, 6 skipped
:kafka-trunk-jdk8:core:test FAILED
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

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

BUILD FAILED in 1h 27m 16s
17 actionable tasks: 2 executed, 15 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] Parsing 1 file in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Successfully parsed file <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/build/reports/findbugs/main.xml> with 0 unique warnings and 0 duplicates.
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=719a21f7c9fefc6ebe16089b2a5e4c155fde8b16, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2519
Recording test results
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user wangguoz@gmail.com
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk