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/03/19 10:12:29 UTC

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

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

Changes:

[mjsax] KAFKA-6486: Implemented LinkedHashMap in TimeWindows (#4628)

------------------------------------------
[...truncated 3.55 MB...]

org.apache.kafka.streams.StreamsConfigTest > shouldThrowExceptionIfBootstrapServersIsNotSet STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldThrowExceptionIfBootstrapServersIsNotSet PASSED

org.apache.kafka.streams.StreamsConfigTest > consumerConfigMustUseAdminClientConfigForRetries STARTED

org.apache.kafka.streams.StreamsConfigTest > consumerConfigMustUseAdminClientConfigForRetries PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnErrorUsingDeprecatedConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnErrorUsingDeprecatedConfigs PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedRestoreConsumerConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldBeSupportNonPrefixedRestoreConsumerConfigs PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedRestoreConsumerConfigs STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSupportPrefixedRestoreConsumerConfigs PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldThrowExceptionIfApplicationIdIsNotSet STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldThrowExceptionIfApplicationIdIsNotSet PASSED

org.apache.kafka.streams.StreamsConfigTest > consumerConfigMustContainStreamPartitionAssignorConfig STARTED

org.apache.kafka.streams.StreamsConfigTest > consumerConfigMustContainStreamPartitionAssignorConfig PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfProducerMaxInFlightRequestPerConnectionsIsOverriddenIfEosEnabled STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldResetToDefaultIfProducerMaxInFlightRequestPerConnectionsIsOverriddenIfEosEnabled PASSED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnError STARTED

org.apache.kafka.streams.StreamsConfigTest > shouldSpecifyCorrectKeySerdeClassOnError PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testShiftOffsetByWhenBetweenBeginningAndEndOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testShiftOffsetByWhenBetweenBeginningAndEndOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetToSpecificOffsetWhenAfterEndOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetToSpecificOffsetWhenAfterEndOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldAcceptValidDateFormats STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldAcceptValidDateFormats PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldDeleteTopic STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldDeleteTopic PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetToSpecificOffsetWhenBetweenBeginningAndEndOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetToSpecificOffsetWhenBetweenBeginningAndEndOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testShiftOffsetByWhenAfterEndOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testShiftOffsetByWhenAfterEndOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetToSpecificOffsetWhenBeforeBeginningOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetToSpecificOffsetWhenBeforeBeginningOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldSeekToEndOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldSeekToEndOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetUsingPlanWhenBetweenBeginningAndEndOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetUsingPlanWhenBetweenBeginningAndEndOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetUsingPlanWhenBeforeBeginningOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetUsingPlanWhenBeforeBeginningOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldThrowOnInvalidDateFormat STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > shouldThrowOnInvalidDateFormat PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetUsingPlanWhenAfterEndOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testResetUsingPlanWhenAfterEndOffset PASSED

org.apache.kafka.streams.tools.StreamsResetterTest > testShiftOffsetByWhenBeforeBeginningOffset STARTED

org.apache.kafka.streams.tools.StreamsResetterTest > testShiftOffsetByWhenBeforeBeginningOffset PASSED

org.apache.kafka.streams.StreamsBuilderTest > testMerge STARTED

org.apache.kafka.streams.StreamsBuilderTest > testMerge PASSED

org.apache.kafka.streams.StreamsBuilderTest > testFrom STARTED

org.apache.kafka.streams.StreamsBuilderTest > testFrom PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedJoinedKTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedJoinedKTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldUseSerdesDefinedInMaterializedToConsumeGlobalTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldUseSerdesDefinedInMaterializedToConsumeGlobalTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedFilteredKTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedFilteredKTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedMapValuedKTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedMapValuedKTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinUnmaterializedMapValuedKTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinUnmaterializedMapValuedKTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinUnmaterializedFilteredKTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinUnmaterializedFilteredKTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldUseSerdesDefinedInMaterializedToConsumeTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldUseSerdesDefinedInMaterializedToConsumeTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldThrowExceptionWhenTopicNamesAreNull STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldThrowExceptionWhenTopicNamesAreNull PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedSourceKTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinMaterializedSourceKTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldThrowExceptionWhenNoTopicPresent STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldThrowExceptionWhenNoTopicPresent PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldUseDefaultNodeAndStoreNames STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldUseDefaultNodeAndStoreNames PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinUnmaterializedJoinedKTable STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldAllowJoinUnmaterializedJoinedKTable PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldProcessingFromSinkTopic STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldProcessingFromSinkTopic PASSED

org.apache.kafka.streams.StreamsBuilderTest > shouldProcessViaThroughTopic STARTED

org.apache.kafka.streams.StreamsBuilderTest > shouldProcessViaThroughTopic PASSED

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

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

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

org.apache.kafka.streams.integration.InternalTopicIntegrationTest > shouldCompactAndDeleteTopicsForWindowStoreChangelogs 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
ERROR: Could not install GRADLE_4_4_HOME
java.lang.NullPointerException
	at hudson.plugins.toolenv.ToolEnvBuildWrapper$1.buildEnvVars(ToolEnvBuildWrapper.java:46)
	at hudson.model.AbstractBuild.getEnvironment(AbstractBuild.java:895)
	at hudson.plugins.git.GitSCM.getParamExpandedRepos(GitSCM.java:458)
	at hudson.plugins.git.GitSCM.compareRemoteRevisionWithImpl(GitSCM.java:666)
	at hudson.plugins.git.GitSCM.compareRemoteRevisionWith(GitSCM.java:631)
	at hudson.scm.SCM.compareRemoteRevisionWith(SCM.java:391)
	at hudson.scm.SCM.poll(SCM.java:408)
	at hudson.model.AbstractProject._poll(AbstractProject.java:1384)
	at hudson.model.AbstractProject.poll(AbstractProject.java:1287)
	at hudson.triggers.SCMTrigger$Runner.runPolling(SCMTrigger.java:594)
	at hudson.triggers.SCMTrigger$Runner.run(SCMTrigger.java:640)
	at hudson.util.SequentialExecutionQueue$QueueEntry.run(SequentialExecutionQueue.java:119)
	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	at java.lang.Thread.run(Thread.java:748)
Build timed out (after 360 minutes). Marking the build as failed.
:streams:test FAILED
Build was aborted

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':streams:test'.
> Process 'Gradle Test Executor 11' finished with non-zero exit value 143

* 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 32m 32s
61 actionable tasks: 58 executed, 3 up-to-date
[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=02a8ef859539349151e9d1dd0c69ac83a24ee7a2, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2477
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

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

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

Changes:

[rajinisivaram] KAFKA-6676: Ensure Kafka chroot exists in system tests and use chroot on

[rajinisivaram] MINOR: Some logging improvements for debugging delayed produce status

------------------------------------------
[...truncated 3.48 MB...]

kafka.controller.ReplicaStateMachineTest > testInvalidNewReplicaToReplicaDeletionIneligibleTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOfflineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOfflineReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionSuccessfulTransition STARTED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionSuccessfulTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToOnlineReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToNewReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidOnlineReplicaToNewReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionIneligibleTransition STARTED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionStartedToReplicaDeletionIneligibleTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToOfflineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionSuccessfulToOfflineReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionIneligibleToNewReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionIneligibleToNewReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionIneligibleToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testReplicaDeletionIneligibleToOnlineReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionStartedToNewReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidReplicaDeletionStartedToNewReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToReplicaDeletionSuccessfulTransition STARTED

kafka.controller.ReplicaStateMachineTest > testInvalidNonexistentReplicaToReplicaDeletionSuccessfulTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.controller.ReplicaStateMachineTest > testNewReplicaToOnlineReplicaTransition STARTED

kafka.controller.ReplicaStateMachineTest > testNewReplicaToOnlineReplicaTransition FAILED
    java.lang.IllegalStateException: Shutdown in progress
        at java.lang.ApplicationShutdownHooks.add(ApplicationShutdownHooks.java:66)
        at java.lang.Runtime.addShutdownHook(Runtime.java:211)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:180)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:150)
        at org.apache.kafka.test.TestUtils.tempDirectory(TestUtils.java:160)
        at kafka.utils.TestUtils$.tempDir(TestUtils.scala:88)
        at kafka.utils.TestUtils$.createBrokerConfig(TestUtils.scala:246)
        at kafka.controller.ReplicaStateMachineTest.<init>(ReplicaStateMachineTest.scala:44)

kafka.message.MessageCompressionTest > testCompressSize STARTED

kafka.message.MessageCompressionTest > testCompressSize PASSED

kafka.message.MessageCompressionTest > testSimpleCompressDecompress STARTED

kafka.message.MessageCompressionTest > testSimpleCompressDecompress PASSED

kafka.message.ByteBufferMessageSetTest > testMessageWithProvidedOffsetSeq STARTED

kafka.message.ByteBufferMessageSetTest > testMessageWithProvidedOffsetSeq PASSED

kafka.message.ByteBufferMessageSetTest > testValidBytes STARTED

kafka.message.ByteBufferMessageSetTest > testValidBytes PASSED

kafka.message.ByteBufferMessageSetTest > testValidBytesWithCompression STARTED

kafka.message.ByteBufferMessageSetTest > testValidBytesWithCompression PASSED

kafka.message.ByteBufferMessageSetTest > testWriteToChannelThatConsumesPartially STARTED

kafka.message.ByteBufferMessageSetTest > testWriteToChannelThatConsumesPartially PASSED

kafka.message.ByteBufferMessageSetTest > testIteratorIsConsistent STARTED

kafka.message.ByteBufferMessageSetTest > testIteratorIsConsistent PASSED

kafka.message.ByteBufferMessageSetTest > testWrittenEqualsRead STARTED

kafka.message.ByteBufferMessageSetTest > testWrittenEqualsRead PASSED

kafka.message.ByteBufferMessageSetTest > testWriteTo STARTED

kafka.message.ByteBufferMessageSetTest > testWriteTo PASSED

kafka.message.ByteBufferMessageSetTest > testEquals STARTED

kafka.message.ByteBufferMessageSetTest > testEquals PASSED

kafka.message.ByteBufferMessageSetTest > testSizeInBytes STARTED

kafka.message.ByteBufferMessageSetTest > testSizeInBytes PASSED

kafka.message.ByteBufferMessageSetTest > testIterator STARTED

kafka.message.ByteBufferMessageSetTest > testIterator PASSED

kafka.message.MessageTest > testChecksum STARTED

kafka.message.MessageTest > testChecksum PASSED

kafka.message.MessageTest > testInvalidTimestamp STARTED

kafka.message.MessageTest > testInvalidTimestamp PASSED

kafka.message.MessageTest > testIsHashable STARTED

kafka.message.MessageTest > testIsHashable PASSED

kafka.message.MessageTest > testInvalidTimestampAndMagicValueCombination STARTED

kafka.message.MessageTest > testInvalidTimestampAndMagicValueCombination PASSED

kafka.message.MessageTest > testExceptionMapping STARTED

kafka.message.MessageTest > testExceptionMapping PASSED

kafka.message.MessageTest > testFieldValues STARTED

kafka.message.MessageTest > testFieldValues PASSED

kafka.message.MessageTest > testInvalidMagicByte STARTED

kafka.message.MessageTest > testInvalidMagicByte PASSED

kafka.message.MessageTest > testEquality STARTED

kafka.message.MessageTest > testEquality PASSED
[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 2 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.
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=7041e76bd6ef0c28ec8de2d07f2208171745f936, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #2477
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