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/21 12:12:35 UTC

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

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

Changes:

[ismael] MINOR: Fix flaky TestUtils functions (#4743)

[jason] MINOR: Remove acceptor creation in network thread update code (#4742)

------------------------------------------
[...truncated 3.47 MB...]
kafka.admin.AdminZkClientTest > testTopicConfigChange STARTED

kafka.admin.AdminZkClientTest > testTopicConfigChange PASSED

kafka.admin.AdminZkClientTest > testManualReplicaAssignment STARTED

kafka.admin.AdminZkClientTest > testManualReplicaAssignment PASSED

kafka.admin.AdminZkClientTest > testConcurrentTopicCreation STARTED

kafka.admin.AdminZkClientTest > testConcurrentTopicCreation PASSED

kafka.admin.AdminZkClientTest > shouldPropagateDynamicBrokerConfigs STARTED

kafka.admin.AdminZkClientTest > shouldPropagateDynamicBrokerConfigs PASSED

kafka.admin.AdminZkClientTest > testTopicCreationWithCollision STARTED

kafka.admin.AdminZkClientTest > testTopicCreationWithCollision PASSED

kafka.admin.AdminZkClientTest > testTopicCreationInZK STARTED

kafka.admin.AdminZkClientTest > testTopicCreationInZK PASSED

kafka.admin.ListConsumerGroupTest > testListOldConsumerGroups STARTED

kafka.admin.ListConsumerGroupTest > testListOldConsumerGroups PASSED

kafka.admin.ListConsumerGroupTest > testListGroupWithNoExistingGroup STARTED

kafka.admin.ListConsumerGroupTest > testListGroupWithNoExistingGroup PASSED

kafka.admin.ListConsumerGroupTest > testListConsumerGroups STARTED

kafka.admin.ListConsumerGroupTest > testListConsumerGroups PASSED

kafka.server.MultipleListenersWithDefaultJaasContextTest > testProduceConsume STARTED

kafka.server.MultipleListenersWithDefaultJaasContextTest > testProduceConsume PASSED

kafka.server.MultipleListenersWithAdditionalJaasContextTest > testProduceConsume STARTED

kafka.server.MultipleListenersWithAdditionalJaasContextTest > testProduceConsume PASSED

kafka.server.epoch.OffsetsForLeaderEpochTest > shouldGetEpochsFromReplica STARTED

kafka.server.epoch.OffsetsForLeaderEpochTest > shouldGetEpochsFromReplica PASSED

kafka.server.epoch.OffsetsForLeaderEpochTest > shouldReturnUnknownTopicOrPartitionIfThrown STARTED

kafka.server.epoch.OffsetsForLeaderEpochTest > shouldReturnUnknownTopicOrPartitionIfThrown PASSED

kafka.server.epoch.OffsetsForLeaderEpochTest > shouldReturnNoLeaderForPartitionIfThrown STARTED

kafka.server.epoch.OffsetsForLeaderEpochTest > shouldReturnNoLeaderForPartitionIfThrown PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldFetchLatestEpochOfEmptyCache STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldFetchLatestEpochOfEmptyCache PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotUpdateEpochAndStartOffsetIfItDidNotChange STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotUpdateEpochAndStartOffsetIfItDidNotChange PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldDropEntriesBetweenEpochBoundaryWhenRemovingNewest STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldDropEntriesBetweenEpochBoundaryWhenRemovingNewest PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnLogEndOffsetIfLatestEpochRequested STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnLogEndOffsetIfLatestEpochRequested PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldAllowLeaderEpochToChangeEvenIfOffsetDoesNot STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldAllowLeaderEpochToChangeEvenIfOffsetDoesNot PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotClearAnythingIfOffsetToEarly STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotClearAnythingIfOffsetToEarly PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldIncreaseAndTrackEpochsAsFollowerReceivesManyMessages STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldIncreaseAndTrackEpochsAsFollowerReceivesManyMessages PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotLetEpochGoBackwardsEvenIfMessageEpochsDo STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotLetEpochGoBackwardsEvenIfMessageEpochsDo PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotOverwriteOffsetForALeaderEpochOnceItHasBeenAssigned STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotOverwriteOffsetForALeaderEpochOnceItHasBeenAssigned PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotOverwriteLogEndOffsetForALeaderEpochOnceItHasBeenAssigned STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotOverwriteLogEndOffsetForALeaderEpochOnceItHasBeenAssigned PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnUndefinedOffsetIfUndefinedEpochRequested STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnUndefinedOffsetIfUndefinedEpochRequested PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldIncreaseAndTrackEpochsAsLeadersChangeManyTimes STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldIncreaseAndTrackEpochsAsLeadersChangeManyTimes PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldSupportEpochsThatDoNotStartFromZero STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldSupportEpochsThatDoNotStartFromZero PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnUnsupportedIfRequestedEpochLessThanFirstEpoch STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnUnsupportedIfRequestedEpochLessThanFirstEpoch PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnNextAvailableEpochIfThereIsNoExactEpochForTheOneRequested STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnNextAvailableEpochIfThereIsNoExactEpochForTheOneRequested PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldAddEpochAndMessageOffsetToCache STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldAddEpochAndMessageOffsetToCache PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldDropEntriesOnEpochBoundaryWhenRemovingLatestEntries STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldDropEntriesOnEpochBoundaryWhenRemovingLatestEntries PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldUpdateSavedOffsetWhenOffsetToClearToIsBetweenEpochs STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldUpdateSavedOffsetWhenOffsetToClearToIsBetweenEpochs PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotResetEpochHistoryTailIfUndefinedPassed STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotResetEpochHistoryTailIfUndefinedPassed PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnUnsupportedIfNoEpochRecorded STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnUnsupportedIfNoEpochRecorded PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldRetainLatestEpochOnClearAllEarliest STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldRetainLatestEpochOnClearAllEarliest PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldPersistEpochsBetweenInstances STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldPersistEpochsBetweenInstances PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotClearAnythingIfOffsetToFirstOffset STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotClearAnythingIfOffsetToFirstOffset PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotLetOffsetsGoBackwardsEvenIfEpochsProgress STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotLetOffsetsGoBackwardsEvenIfEpochsProgress PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldGetFirstOffsetOfSubsequentEpochWhenOffsetRequestedForPreviousEpoch STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldGetFirstOffsetOfSubsequentEpochWhenOffsetRequestedForPreviousEpoch PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldUpdateOffsetBetweenEpochBoundariesOnClearEarliest2 STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldUpdateOffsetBetweenEpochBoundariesOnClearEarliest2 PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldClearEarliestOnEmptyCache STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldClearEarliestOnEmptyCache PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldPreserveResetOffsetOnClearEarliestIfOneExists STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldPreserveResetOffsetOnClearEarliestIfOneExists PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldUpdateOffsetBetweenEpochBoundariesOnClearEarliest STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldUpdateOffsetBetweenEpochBoundariesOnClearEarliest PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnInvalidOffsetIfEpochIsRequestedWhichIsNotCurrentlyTracked STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldReturnInvalidOffsetIfEpochIsRequestedWhichIsNotCurrentlyTracked PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldFetchEndOffsetOfEmptyCache STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldFetchEndOffsetOfEmptyCache PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldRetainLatestEpochOnClearAllEarliestAndUpdateItsOffset STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldRetainLatestEpochOnClearAllEarliestAndUpdateItsOffset PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldClearAllEntries STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldClearAllEntries PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldClearLatestOnEmptyCache STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldClearLatestOnEmptyCache PASSED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotResetEpochHistoryHeadIfUndefinedPassed STARTED

kafka.server.epoch.LeaderEpochFileCacheTest > shouldNotResetEpochHistoryHeadIfUndefinedPassed PASSED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > shouldSurviveFastLeaderChange STARTED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > shouldSurviveFastLeaderChange PASSED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > offsetsShouldNotGoBackwards STARTED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > offsetsShouldNotGoBackwards PASSED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > shouldFollowLeaderEpochBasicWorkflow STARTED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > shouldFollowLeaderEpochBasicWorkflow PASSED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > shouldNotAllowDivergentLogs STARTED
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.
Build was aborted
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
:core:test FAILED
[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=2f90cb86c18e854fd687ea7bbeb8692178bbb02d, 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 rajinisivaram@googlemail.com
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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


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

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

Changes:

[github] MINOR: Change getMessage to toString (#4790)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 28f1fc2f55269f43f0b2bb769b78f80b8cc9cf51 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 28f1fc2f55269f43f0b2bb769b78f80b8cc9cf51
Commit message: "MINOR: Change getMessage to toString (#4790)"
 > git rev-list --no-walk 659fbb0b06a79fa7e94ac0d68925b1718ed3f214 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins5665307415867882142.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 12s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins3890543956191425753.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 13s
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] No files found. Configuration error?
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=28f1fc2f55269f43f0b2bb769b78f80b8cc9cf51, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[jason] KAFKA-6724; ConsumerPerformance should not always reset to earliest

[wangguoz] MINOR: Depend on streams:test-utils for streams and examples tests

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 659fbb0b06a79fa7e94ac0d68925b1718ed3f214 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 659fbb0b06a79fa7e94ac0d68925b1718ed3f214
Commit message: "MINOR: Depend on streams:test-utils for streams and examples tests (#4760)"
 > git rev-list --no-walk 5d5a2ce4bba4b42b3652d0126d1d2dab979a3e07 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins8263028477061057869.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 14s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins2933121142005448784.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 15s
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] No files found. Configuration error?
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=659fbb0b06a79fa7e94ac0d68925b1718ed3f214, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[rajinisivaram] KAFKA-6716: Should close the `discardChannel` in

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 5d5a2ce4bba4b42b3652d0126d1d2dab979a3e07 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 5d5a2ce4bba4b42b3652d0126d1d2dab979a3e07
Commit message: "KAFKA-6716: Should close the `discardChannel` in MockSelector#completeSend (#4783)"
 > git rev-list --no-walk 9baa9bddba0dc1b3bda167ea509bd90226615e1f # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins965377224803695451.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 12s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins7951002238980797577.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 13s
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] No files found. Configuration error?
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=5d5a2ce4bba4b42b3652d0126d1d2dab979a3e07, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[jason] MINOR: Update Jackson to 2.9.5 (#4776)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 9baa9bddba0dc1b3bda167ea509bd90226615e1f (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 9baa9bddba0dc1b3bda167ea509bd90226615e1f
Commit message: "MINOR: Update Jackson to 2.9.5 (#4776)"
 > git rev-list --no-walk 281dbfd9813603d913a2a0b948547dea7b863be2 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins4749715464473888829.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 12s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins5053017237484270459.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 13s
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] No files found. Configuration error?
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=9baa9bddba0dc1b3bda167ea509bd90226615e1f, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[github] MINOR: LogCleaner.validateReconfiguration fixes (#4770)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H20 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 281dbfd9813603d913a2a0b948547dea7b863be2 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 281dbfd9813603d913a2a0b948547dea7b863be2
Commit message: "MINOR: LogCleaner.validateReconfiguration fixes (#4770)"
 > git rev-list --no-walk 964693e40d9303d5d754010f03731d2134bae749 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins2566104473555511134.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 11s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins8269141900135802642.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 11s
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] No files found. Configuration error?
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=281dbfd9813603d913a2a0b948547dea7b863be2, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[wangguoz] KAFKA-6386: Use Properties instead of StreamsConfig in KafkaStreams

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 964693e40d9303d5d754010f03731d2134bae749 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 964693e40d9303d5d754010f03731d2134bae749
Commit message: "KAFKA-6386: Use Properties instead of StreamsConfig in KafkaStreams constructor"
 > git rev-list --no-walk adbf31ab1d27cda0b62d611e6141d830736a8e2e # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins8762730662355968411.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 12s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins7743139459494313485.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 13s
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] No files found. Configuration error?
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=964693e40d9303d5d754010f03731d2134bae749, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[jason] MINOR: Fix

[mjsax] KAFKA-6473: Add MockProcessorContext to public test-utils (#4736)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision adbf31ab1d27cda0b62d611e6141d830736a8e2e (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f adbf31ab1d27cda0b62d611e6141d830736a8e2e
Commit message: "KAFKA-6473: Add MockProcessorContext to public test-utils (#4736)"
 > git rev-list --no-walk 9eb32eaad5fa3863d60b84ef095fa041e83b7b47 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins5833152009963923345.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 14s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins3166423030086748711.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 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] No files found. Configuration error?
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=adbf31ab1d27cda0b62d611e6141d830736a8e2e, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[jason] KAFKA-6446; KafkaProducer initTransactions() should timeout after

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 9eb32eaad5fa3863d60b84ef095fa041e83b7b47 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 9eb32eaad5fa3863d60b84ef095fa041e83b7b47
Commit message: "KAFKA-6446; KafkaProducer initTransactions() should timeout after max.block.ms (#4563)"
 > git rev-list --no-walk f4a39f9b8314847ffc7250f8cee3e87795b0aaeb # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins4870681925641617650.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 15s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins3945544624483983940.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 15s
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] No files found. Configuration error?
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=9eb32eaad5fa3863d60b84ef095fa041e83b7b47, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[wangguoz] MINOR: Fix flaky standby task test (#4767)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H20 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-trunk-jdk8/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision f4a39f9b8314847ffc7250f8cee3e87795b0aaeb (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f f4a39f9b8314847ffc7250f8cee3e87795b0aaeb
Commit message: "MINOR: Fix flaky standby task test (#4767)"
 > git rev-list --no-walk 3f611044cc55c6633cb64fd86a3ac6274952fa72 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins5969965851527679050.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Download https://repo.maven.apache.org/maven2/org/owasp/dependency-check-gradle/3.1.1/dependency-check-gradle-3.1.1.pom
Download https://jcenter.bintray.com/org/ajoberstar/grgit/1.9.3/grgit-1.9.3.pom
Download https://jcenter.bintray.com/com/github/ben-manes/gradle-versions-plugin/0.17.0/gradle-versions-plugin-0.17.0.pom
Download https://jcenter.bintray.com/com/github/jengelman/gradle/plugins/shadow/2.0.2/shadow-2.0.2.pom
Download https://repo.maven.apache.org/maven2/org/owasp/dependency-check-utils/3.1.1/dependency-check-utils-3.1.1.pom
Download https://repo.maven.apache.org/maven2/org/owasp/dependency-check-core/3.1.1/dependency-check-core-3.1.1.pom
Download https://repo.maven.apache.org/maven2/org/owasp/dependency-check-parent/3.1.1/dependency-check-parent-3.1.1.pom
Download https://repo.maven.apache.org/maven2/com/vdurmont/semver4j/2.1.0/semver4j-2.1.0.pom
Download https://repo.maven.apache.org/maven2/org/jsoup/jsoup/1.11.2/jsoup-1.11.2.pom
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-queryparser/5.5.5/lucene-queryparser-5.5.5.pom
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-analyzers-common/5.5.5/lucene-analyzers-common-5.5.5.pom
Download https://repo.maven.apache.org/maven2/com/google/code/gson/gson/2.8.2/gson-2.8.2.pom
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-core/5.5.5/lucene-core-5.5.5.pom
Download https://repo.maven.apache.org/maven2/com/sun/mail/mailapi/1.6.0/mailapi-1.6.0.pom
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-parent/5.5.5/lucene-parent-5.5.5.pom
Download https://repo.maven.apache.org/maven2/com/google/code/gson/gson-parent/2.8.2/gson-parent-2.8.2.pom
Download https://repo.maven.apache.org/maven2/com/sun/mail/all/1.6.0/all-1.6.0.pom
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-solr-grandparent/5.5.5/lucene-solr-grandparent-5.5.5.pom
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-sandbox/5.5.5/lucene-sandbox-5.5.5.pom
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-queries/5.5.5/lucene-queries-5.5.5.pom
Download https://repo.maven.apache.org/maven2/org/owasp/dependency-check-utils/3.1.1/dependency-check-utils-3.1.1.jar
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-analyzers-common/5.5.5/lucene-analyzers-common-5.5.5.jar
Download https://repo.maven.apache.org/maven2/org/owasp/dependency-check-gradle/3.1.1/dependency-check-gradle-3.1.1.jar
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-queryparser/5.5.5/lucene-queryparser-5.5.5.jar
Download https://repo.maven.apache.org/maven2/com/vdurmont/semver4j/2.1.0/semver4j-2.1.0.jar
Download https://repo.maven.apache.org/maven2/org/jsoup/jsoup/1.11.2/jsoup-1.11.2.jar
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-core/5.5.5/lucene-core-5.5.5.jar
Download https://repo.maven.apache.org/maven2/com/sun/mail/mailapi/1.6.0/mailapi-1.6.0.jar
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-sandbox/5.5.5/lucene-sandbox-5.5.5.jar
Download https://repo.maven.apache.org/maven2/com/google/code/gson/gson/2.8.2/gson-2.8.2.jar
Download https://repo.maven.apache.org/maven2/org/owasp/dependency-check-core/3.1.1/dependency-check-core-3.1.1.jar
Download https://repo.maven.apache.org/maven2/org/apache/lucene/lucene-queries/5.5.5/lucene-queries-5.5.5.jar
Download https://jcenter.bintray.com/com/github/ben-manes/gradle-versions-plugin/0.17.0/gradle-versions-plugin-0.17.0.jar
Download https://jcenter.bintray.com/org/ajoberstar/grgit/1.9.3/grgit-1.9.3.jar
Download https://jcenter.bintray.com/com/github/jengelman/gradle/plugins/shadow/2.0.2/shadow-2.0.2.jar
Building project 'core' with Scala version 2.11.12
Download https://repo.maven.apache.org/maven2/org/scoverage/scalac-scoverage-plugin_2.11/1.3.1/scalac-scoverage-plugin_2.11-1.3.1.pom
Download https://repo.maven.apache.org/maven2/org/scoverage/scalac-scoverage-runtime_2.11/1.3.1/scalac-scoverage-runtime_2.11-1.3.1.pom
Download https://repo.maven.apache.org/maven2/org/scoverage/scalac-scoverage-plugin_2.11/1.3.1/scalac-scoverage-plugin_2.11-1.3.1.jar
Download https://repo.maven.apache.org/maven2/org/scoverage/scalac-scoverage-runtime_2.11/1.3.1/scalac-scoverage-runtime_2.11-1.3.1.jar
:downloadWrapper

BUILD SUCCESSFUL in 14s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins5571881948268800987.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
Downloading https://services.gradle.org/distributions/gradle-4.6-bin.zip
......................................................................
Unzipping /home/jenkins/.gradle/wrapper/dists/gradle-4.6-bin/4jp4stjndanmxuerzfseyb6wo/gradle-4.6-bin.zip to /home/jenkins/.gradle/wrapper/dists/gradle-4.6-bin/4jp4stjndanmxuerzfseyb6wo
Set executable permissions for: /home/jenkins/.gradle/wrapper/dists/gradle-4.6-bin/4jp4stjndanmxuerzfseyb6wo/gradle-4.6/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 19s
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] No files found. Configuration error?
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=f4a39f9b8314847ffc7250f8cee3e87795b0aaeb, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[github] KAFKA-6710: Remove Thread.sleep from LogManager.deleteLogs (#4771)

[jason] KAFKA-6052; Fix WriteTxnMarkers request retry issue in

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 3f611044cc55c6633cb64fd86a3ac6274952fa72 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 3f611044cc55c6633cb64fd86a3ac6274952fa72
Commit message: "KAFKA-6052; Fix WriteTxnMarkers request retry issue in InterBrokerSendThread (#4705)"
 > git rev-list --no-walk 514936af6f04e00ad908d3835040db5b0d5698c2 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins1936434988980492786.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 12s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins1395024585121573899.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 13s
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] No files found. Configuration error?
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=3f611044cc55c6633cb64fd86a3ac6274952fa72, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[jason] KAFKA-6637; Avoid divide by zero error with segment.ms set to zero

[jason] MINOR: Fix potential resource leak in FileOffsetBackingStore (#4739)

[jason] MINOR: Remove redundant initialization of `Stats.index` (#4751)

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 514936af6f04e00ad908d3835040db5b0d5698c2 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 514936af6f04e00ad908d3835040db5b0d5698c2
Commit message: "MINOR: Remove redundant initialization of `Stats.index` (#4751)"
 > git rev-list --no-walk 685fd03dda02957a91a50fa16409400b1ea08f81 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins2169368209651826808.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 12s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins5312380600977425800.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean UP-TO-DATE
:clients:clean UP-TO-DATE
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 13s
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] No files found. Configuration error?
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=514936af6f04e00ad908d3835040db5b0d5698c2, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[jqin] KAFKA-6612: Added logic to prevent increasing partition counts during

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H25 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 685fd03dda02957a91a50fa16409400b1ea08f81 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 685fd03dda02957a91a50fa16409400b1ea08f81
Commit message: "KAFKA-6612: Added logic to prevent increasing partition counts during topic deletion"
 > git rev-list --no-walk 2307314432c871cf045787b44295d8dc4943e77d # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins5256417220845519096.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 10s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins503501538715288885.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean
:clients:clean
:connect:clean UP-TO-DATE
:core:clean
:examples:clean
:jmh-benchmarks:clean
:log4j-appender:clean
:streams:clean
:tools:clean
:connect:api:clean
:connect:file:clean
:connect:json:clean
:connect:runtime:clean
:connect:transforms:clean
:streams:examples:clean
:streams:test-utils:clean
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 12s
17 actionable tasks: 16 executed, 1 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] No files found. Configuration error?
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=685fd03dda02957a91a50fa16409400b1ea08f81, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[github] MINOR: Fix encoder config to make DynamicBrokerReconfigurationTest

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H32 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 2307314432c871cf045787b44295d8dc4943e77d (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 2307314432c871cf045787b44295d8dc4943e77d
Commit message: "MINOR: Fix encoder config to make DynamicBrokerReconfigurationTest stable (#4764)"
 > git rev-list --no-walk 395dcad7d9208aad5399222e1d19a13fecf035c9 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins2424108832794129170.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 16s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins4199353880981723052.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean
:clients:clean
:connect:clean UP-TO-DATE
:core:clean
:examples:clean UP-TO-DATE
:jmh-benchmarks:clean UP-TO-DATE
:log4j-appender:clean UP-TO-DATE
:streams:clean UP-TO-DATE
:tools:clean UP-TO-DATE
:connect:api:clean UP-TO-DATE
:connect:file:clean UP-TO-DATE
:connect:json:clean UP-TO-DATE
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 15s
17 actionable tasks: 4 executed, 13 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] No files found. Configuration error?
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=2307314432c871cf045787b44295d8dc4943e77d, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[ismael] KAFKA-6683; Ensure producer state not mutated prior to append (#4755)

[github] MINOR: Java 9/10 fixes, gradle and minor deps update (#4725)

------------------------------------------
Started by an SCM change
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H21 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
 > git rev-parse --is-inside-work-tree # timeout=10
Fetching changes from the remote Git repository
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/trunk^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/trunk^{commit} # timeout=10
Checking out Revision 395dcad7d9208aad5399222e1d19a13fecf035c9 (refs/remotes/origin/trunk)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 395dcad7d9208aad5399222e1d19a13fecf035c9
Commit message: "MINOR: Java 9/10 fixes, gradle and minor deps update (#4725)"
 > git rev-list --no-walk f2fbfaaccc99f889ae0796005a46d6c62c8e5be9 # timeout=10
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins2168599442534268181.sh
+ rm -rf <https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.4/bin/gradle
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.4.1/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:downloadWrapper

BUILD SUCCESSFUL in 10s
1 actionable task: 1 executed
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
[kafka-trunk-jdk8] $ /bin/bash -xe /tmp/jenkins4678251536690754066.sh
+ export GRADLE_OPTS=-Xmx1024m
+ GRADLE_OPTS=-Xmx1024m
+ ./gradlew --no-daemon -PmaxParallelForks=1 -PtestLoggingEvents=started,passed,skipped,failed -PxmlFindBugsReport=true clean testAll
To honour the JVM settings for this build a new JVM will be forked. Please consider using the daemon: https://docs.gradle.org/4.6/userguide/gradle_daemon.html.
Daemon will be stopped at the end of the build stopping after processing
Building project 'core' with Scala version 2.11.12
:clean
:clients:clean
:connect:clean UP-TO-DATE
:core:clean
:examples:clean
:jmh-benchmarks:clean
:log4j-appender:clean
:streams:clean
:tools:clean UP-TO-DATE
:connect:api:clean
:connect:file:clean UP-TO-DATE
:connect:json:clean
:connect:runtime:clean UP-TO-DATE
:connect:transforms:clean UP-TO-DATE
:streams:examples:clean UP-TO-DATE
:streams:test-utils:clean UP-TO-DATE
:test_core_2_11
Building project 'core' with Scala version 2.11.12
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Could not determine the dependencies of task ':kafka-trunk-jdk8:clients:compileJava'.
> Could not create service of type AnnotationProcessorDetector using JavaGradleScopeServices.createAnnotationProcessorDetector().

* 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 11s
17 actionable tasks: 10 executed, 7 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] No files found. Configuration error?
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=395dcad7d9208aad5399222e1d19a13fecf035c9, 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
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4
Not sending mail to unregistered user ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[mjsax] KAFKA-6659: Improve error message if state store is not found (#4732)

[mjsax] MINOR: Rolling bounce upgrade fixed broker system test (#4690)

[github] KAFKA-6611: PART I, Use JMXTool in SimpleBenchmark (#4650)

------------------------------------------
[...truncated 3.53 MB...]
kafka.network.SocketServerTest > testRequestMetricsAfterStop PASSED

kafka.network.SocketServerTest > testConnectionIdReuse STARTED

kafka.network.SocketServerTest > testConnectionIdReuse PASSED

kafka.network.SocketServerTest > testClientDisconnectionUpdatesRequestMetrics STARTED

kafka.network.SocketServerTest > testClientDisconnectionUpdatesRequestMetrics PASSED

kafka.network.SocketServerTest > testProcessorMetricsTags STARTED

kafka.network.SocketServerTest > testProcessorMetricsTags PASSED

kafka.network.SocketServerTest > testMaxConnectionsPerIp STARTED

kafka.network.SocketServerTest > testMaxConnectionsPerIp PASSED

kafka.network.SocketServerTest > testConnectionId STARTED

kafka.network.SocketServerTest > testConnectionId PASSED

kafka.network.SocketServerTest > testBrokerSendAfterChannelClosedUpdatesRequestMetrics STARTED

kafka.network.SocketServerTest > testBrokerSendAfterChannelClosedUpdatesRequestMetrics PASSED

kafka.network.SocketServerTest > testNoOpAction STARTED

kafka.network.SocketServerTest > testNoOpAction PASSED

kafka.network.SocketServerTest > simpleRequest STARTED

kafka.network.SocketServerTest > simpleRequest PASSED

kafka.network.SocketServerTest > closingChannelException STARTED

kafka.network.SocketServerTest > closingChannelException PASSED

kafka.network.SocketServerTest > testIdleConnection STARTED

kafka.network.SocketServerTest > testIdleConnection PASSED

kafka.network.SocketServerTest > testClientDisconnectionWithStagedReceivesFullyProcessed STARTED

kafka.network.SocketServerTest > testClientDisconnectionWithStagedReceivesFullyProcessed PASSED

kafka.network.SocketServerTest > testMetricCollectionAfterShutdown STARTED

kafka.network.SocketServerTest > testMetricCollectionAfterShutdown PASSED

kafka.network.SocketServerTest > testSessionPrincipal STARTED

kafka.network.SocketServerTest > testSessionPrincipal PASSED

kafka.network.SocketServerTest > configureNewConnectionException STARTED

kafka.network.SocketServerTest > configureNewConnectionException PASSED

kafka.network.SocketServerTest > testMaxConnectionsPerIpOverrides STARTED

kafka.network.SocketServerTest > testMaxConnectionsPerIpOverrides PASSED

kafka.network.SocketServerTest > processNewResponseException STARTED

kafka.network.SocketServerTest > processNewResponseException PASSED

kafka.network.SocketServerTest > processCompletedSendException STARTED

kafka.network.SocketServerTest > processCompletedSendException PASSED

kafka.network.SocketServerTest > processDisconnectedException STARTED

kafka.network.SocketServerTest > processDisconnectedException PASSED

kafka.network.SocketServerTest > sendCancelledKeyException STARTED

kafka.network.SocketServerTest > sendCancelledKeyException PASSED

kafka.network.SocketServerTest > processCompletedReceiveException STARTED

kafka.network.SocketServerTest > processCompletedReceiveException PASSED

kafka.network.SocketServerTest > testSocketsCloseOnShutdown STARTED

kafka.network.SocketServerTest > testSocketsCloseOnShutdown PASSED

kafka.network.SocketServerTest > pollException STARTED

kafka.network.SocketServerTest > pollException PASSED

kafka.network.SocketServerTest > testSslSocketServer STARTED

kafka.network.SocketServerTest > testSslSocketServer PASSED

kafka.network.SocketServerTest > tooBigRequestIsRejected STARTED

kafka.network.SocketServerTest > tooBigRequestIsRejected PASSED

kafka.integration.PrimitiveApiTest > testMultiProduce STARTED

kafka.integration.PrimitiveApiTest > testMultiProduce PASSED

kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch STARTED

kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetch PASSED

kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize STARTED

kafka.integration.PrimitiveApiTest > testFetchRequestCanProperlySerialize PASSED

kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests STARTED

kafka.integration.PrimitiveApiTest > testPipelinedProduceRequests PASSED

kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch STARTED

kafka.integration.PrimitiveApiTest > testProduceAndMultiFetch PASSED

kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetchWithCompression STARTED

kafka.integration.PrimitiveApiTest > testDefaultEncoderProducerAndFetchWithCompression PASSED

kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic STARTED

kafka.integration.PrimitiveApiTest > testConsumerEmptyTopic PASSED

kafka.integration.PrimitiveApiTest > testEmptyFetchRequest STARTED

kafka.integration.PrimitiveApiTest > testEmptyFetchRequest PASSED

kafka.integration.MetricsDuringTopicCreationDeletionTest > testMetricsDuringTopicCreateDelete STARTED

kafka.integration.MetricsDuringTopicCreationDeletionTest > testMetricsDuringTopicCreateDelete PASSED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabled PASSED

kafka.integration.UncleanLeaderElectionTest > testCleanLeaderElectionDisabledByTopicOverride STARTED

kafka.integration.UncleanLeaderElectionTest > testCleanLeaderElectionDisabledByTopicOverride SKIPPED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionDisabled SKIPPED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionInvalidTopicOverride PASSED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride STARTED

kafka.integration.UncleanLeaderElectionTest > testUncleanLeaderElectionEnabledByTopicOverride PASSED

kafka.integration.MinIsrConfigTest > testDefaultKafkaConfig STARTED

kafka.integration.MinIsrConfigTest > testDefaultKafkaConfig PASSED

kafka.integration.TopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack STARTED

kafka.integration.TopicMetadataTest > testIsrAfterBrokerShutDownAndJoinsBack PASSED

kafka.integration.TopicMetadataTest > testAutoCreateTopicWithCollision STARTED

kafka.integration.TopicMetadataTest > testAutoCreateTopicWithCollision PASSED

kafka.integration.TopicMetadataTest > testAliveBrokerListWithNoTopics STARTED

kafka.integration.TopicMetadataTest > testAliveBrokerListWithNoTopics PASSED

kafka.integration.TopicMetadataTest > testAutoCreateTopic STARTED

kafka.integration.TopicMetadataTest > testAutoCreateTopic PASSED

kafka.integration.TopicMetadataTest > testGetAllTopicMetadata STARTED

kafka.integration.TopicMetadataTest > testGetAllTopicMetadata PASSED

kafka.integration.TopicMetadataTest > testAliveBrokersListWithNoTopicsAfterNewBrokerStartup STARTED

kafka.integration.TopicMetadataTest > testAliveBrokersListWithNoTopicsAfterNewBrokerStartup PASSED

kafka.integration.TopicMetadataTest > testBasicTopicMetadata STARTED

kafka.integration.TopicMetadataTest > testBasicTopicMetadata PASSED

kafka.integration.TopicMetadataTest > testAutoCreateTopicWithInvalidReplication STARTED

kafka.integration.TopicMetadataTest > testAutoCreateTopicWithInvalidReplication PASSED

kafka.integration.TopicMetadataTest > testAliveBrokersListWithNoTopicsAfterABrokerShutdown STARTED

kafka.integration.TopicMetadataTest > testAliveBrokersListWithNoTopicsAfterABrokerShutdown PASSED

kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow STARTED

kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooLow PASSED

kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow STARTED

kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooLow PASSED

kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh STARTED

kafka.integration.AutoOffsetResetTest > testResetToEarliestWhenOffsetTooHigh PASSED

kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh STARTED

kafka.integration.AutoOffsetResetTest > testResetToLatestWhenOffsetTooHigh PASSED

kafka.integration.FetcherTest > testFetcher STARTED

kafka.integration.FetcherTest > testFetcher PASSED

1900 tests completed, 1 failed, 6 skipped
:core:test FAILED

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-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 5m 55s
32 actionable tasks: 29 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 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=f2fbfaaccc99f889ae0796005a46d6c62c8e5be9, 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 ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[github] MINOR: Fix AdminClient.describeConfigs() of listener configs (#4747)

------------------------------------------
[...truncated 3.67 MB...]

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > testPutGetRange PASSED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > shouldThrowNullPointerExceptionOnGetNullKey STARTED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > shouldThrowNullPointerExceptionOnGetNullKey PASSED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > shouldThrowNullPointerExceptionOnRangeNullFromKey STARTED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > shouldThrowNullPointerExceptionOnRangeNullFromKey PASSED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > shouldThrowNullPointerExceptionOnDeleteNullKey STARTED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > shouldThrowNullPointerExceptionOnDeleteNullKey PASSED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > testPutGetRangeWithDefaultSerdes STARTED

org.apache.kafka.streams.state.internals.RocksDBKeyValueStoreTest > testPutGetRangeWithDefaultSerdes PASSED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordFetchLatency STARTED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordFetchLatency PASSED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordFetchRangeLatency STARTED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordFetchRangeLatency PASSED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldCloseUnderlyingStore STARTED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldCloseUnderlyingStore PASSED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordFlushLatency STARTED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordFlushLatency PASSED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordPutLatency STARTED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordPutLatency PASSED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordRestoreLatencyOnInit STARTED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldRecordRestoreLatencyOnInit PASSED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldNotExceptionIfFetchReturnsNull STARTED

org.apache.kafka.streams.state.internals.MeteredWindowStoreTest > shouldNotExceptionIfFetchReturnsNull PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentSessionStoreRetentionPeriodIsNegative STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentSessionStoreRetentionPeriodIsNegative PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreateInMemoryKeyValueStore STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreateInMemoryKeyValueStore PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreIfWindowSizeIsNegative STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreIfWindowSizeIsNegative PASSED

org.apache.kafka.streams.state.StoresTest > shouldBuildWindowStore STARTED

org.apache.kafka.streams.state.StoresTest > shouldBuildWindowStore PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreateRocksDbSessionStore STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreateRocksDbSessionStore PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIllegalArgumentExceptionWhenTryingToConstructWindowStoreWithLessThanTwoSegments STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIllegalArgumentExceptionWhenTryingToConstructWindowStoreWithLessThanTwoSegments PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIMemoryKeyValueStoreStoreNameIsNull STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIMemoryKeyValueStoreStoreNameIsNull PASSED

org.apache.kafka.streams.state.StoresTest > shouldBuildKeyValueStore STARTED

org.apache.kafka.streams.state.StoresTest > shouldBuildKeyValueStore PASSED

org.apache.kafka.streams.state.StoresTest > shouldBuildSessionStore STARTED

org.apache.kafka.streams.state.StoresTest > shouldBuildSessionStore PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfSupplierIsNullForWindowStoreBuilder STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfSupplierIsNullForWindowStoreBuilder PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfSupplierIsNullForSessionStoreBuilder STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfSupplierIsNullForSessionStoreBuilder PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreateInMemoryStoreSupplierWithLoggedConfig STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreateInMemoryStoreSupplierWithLoggedConfig PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfILruMapStoreCapacityIsNegative STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfILruMapStoreCapacityIsNegative PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfSupplierIsNullForKeyValueStoreBuilder STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfSupplierIsNullForKeyValueStoreBuilder PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreateMemoryNavigableCache STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreateMemoryNavigableCache PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreRetentionPeriodIsNegative STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreRetentionPeriodIsNegative PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreIfNumberOfSegmentsSmallerThanOne STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreIfNumberOfSegmentsSmallerThanOne PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreateRocksDbStore STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreateRocksDbStore PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreatePersistenStoreSupplierNotLogged STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreatePersistenStoreSupplierNotLogged PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreStoreNameIsNull STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentWindowStoreStoreNameIsNull PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreatePersistenStoreSupplierWithLoggedConfig STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreatePersistenStoreSupplierWithLoggedConfig PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfPersistentKeyValueStoreStoreNameIsNull STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfPersistentKeyValueStoreStoreNameIsNull PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreateRocksDbWindowStore STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreateRocksDbWindowStore PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfILruMapStoreNameIsNull STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfILruMapStoreNameIsNull PASSED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentSessionStoreStoreNameIsNull STARTED

org.apache.kafka.streams.state.StoresTest > shouldThrowIfIPersistentSessionStoreStoreNameIsNull PASSED

org.apache.kafka.streams.state.StoresTest > shouldCreateInMemoryStoreSupplierNotLogged STARTED

org.apache.kafka.streams.state.StoresTest > shouldCreateInMemoryStoreSupplierNotLogged PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testInnerRepartitioned[caching enabled = true] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testInnerRepartitioned[caching enabled = true] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testOuterRepartitioned[caching enabled = true] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testOuterRepartitioned[caching enabled = true] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testInner[caching enabled = true] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testInner[caching enabled = true] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testOuter[caching enabled = true] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testOuter[caching enabled = true] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testLeft[caching enabled = true] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testLeft[caching enabled = true] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testMultiInner[caching enabled = true] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testMultiInner[caching enabled = true] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testLeftRepartitioned[caching enabled = true] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testLeftRepartitioned[caching enabled = true] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testInnerRepartitioned[caching enabled = false] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testInnerRepartitioned[caching enabled = false] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testOuterRepartitioned[caching enabled = false] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testOuterRepartitioned[caching enabled = false] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testInner[caching enabled = false] STARTED

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

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

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

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

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

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testMultiInner[caching enabled = false] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testMultiInner[caching enabled = false] PASSED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testLeftRepartitioned[caching enabled = false] STARTED

org.apache.kafka.streams.integration.StreamStreamJoinIntegrationTest > testLeftRepartitioned[caching enabled = false] 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.
Build was aborted
[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=57b1c28d60e05f2cf7394ef727a86df92b1bb02b, 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 ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com

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

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

Changes:

[github] MINOR: remove obsolete warning in StreamsResetter (#4749)

------------------------------------------
[...truncated 421.09 KB...]
kafka.api.SaslClientsWithInvalidCredentialsTest > testManualAssignmentConsumerWithAutoCommitDisabledWithAuthenticationFailure PASSED

kafka.api.SaslClientsWithInvalidCredentialsTest > testKafkaAdminClientWithAuthenticationFailure STARTED

kafka.api.SaslClientsWithInvalidCredentialsTest > testKafkaAdminClientWithAuthenticationFailure PASSED

kafka.api.SaslClientsWithInvalidCredentialsTest > testConsumerWithAuthenticationFailure STARTED

kafka.api.SaslClientsWithInvalidCredentialsTest > testConsumerWithAuthenticationFailure PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testProduceConsumeViaAssign STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testProduceConsumeViaAssign PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoGroupAcl STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoGroupAcl PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoProduceWithDescribeAcl STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoProduceWithDescribeAcl PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testProduceConsumeViaSubscribe STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testProduceConsumeViaSubscribe PASSED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoProduceWithoutDescribeAcl STARTED

kafka.api.DelegationTokenEndToEndAuthorizationTest > testNoProduceWithoutDescribeAcl PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testTwoConsumersWithDifferentSaslCredentials STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testTwoConsumersWithDifferentSaslCredentials PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testProduceConsumeViaAssign STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testProduceConsumeViaAssign PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoGroupAcl STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoGroupAcl PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoProduceWithDescribeAcl STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoProduceWithDescribeAcl PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testProduceConsumeViaSubscribe STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testProduceConsumeViaSubscribe PASSED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoProduceWithoutDescribeAcl STARTED

kafka.api.SaslGssapiSslEndToEndAuthorizationTest > testNoProduceWithoutDescribeAcl PASSED

kafka.api.TransactionsTest > testBasicTransactions STARTED

kafka.api.TransactionsTest > testBasicTransactions PASSED

kafka.api.TransactionsTest > testFencingOnSendOffsets STARTED

kafka.api.TransactionsTest > testFencingOnSendOffsets PASSED

kafka.api.TransactionsTest > testFencingOnAddPartitions STARTED

kafka.api.TransactionsTest > testFencingOnAddPartitions PASSED

kafka.api.TransactionsTest > testFencingOnTransactionExpiration STARTED

kafka.api.TransactionsTest > testFencingOnTransactionExpiration PASSED

kafka.api.TransactionsTest > testDelayedFetchIncludesAbortedTransaction STARTED

kafka.api.TransactionsTest > testDelayedFetchIncludesAbortedTransaction PASSED

kafka.api.TransactionsTest > testReadCommittedConsumerShouldNotSeeUndecidedData STARTED

kafka.api.TransactionsTest > testReadCommittedConsumerShouldNotSeeUndecidedData PASSED

kafka.api.TransactionsTest > testFencingOnSend STARTED

kafka.api.TransactionsTest > testFencingOnSend PASSED

kafka.api.TransactionsTest > testFencingOnCommit STARTED

kafka.api.TransactionsTest > testFencingOnCommit PASSED

kafka.api.TransactionsTest > testMultipleMarkersOneLeader STARTED

kafka.api.TransactionsTest > testMultipleMarkersOneLeader PASSED

kafka.api.TransactionsTest > testSendOffsets STARTED

kafka.api.TransactionsTest > testSendOffsets PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testProduceConsumeViaAssign STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testProduceConsumeViaAssign PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoGroupAcl STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoGroupAcl PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoProduceWithDescribeAcl STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoProduceWithDescribeAcl PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testProduceConsumeViaSubscribe STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testProduceConsumeViaSubscribe PASSED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoProduceWithoutDescribeAcl STARTED

kafka.api.PlaintextEndToEndAuthorizationTest > testNoProduceWithoutDescribeAcl 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

1899 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 26m 51s
17 actionable tasks: 4 executed, 13 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=f0a29a693548efe539cba04807e21862c8dfc1bf, 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 ismael@juma.me.uk
Not sending mail to unregistered user rajinisivaram@googlemail.com
Not sending mail to unregistered user github@alasdairhodge.co.uk
Not sending mail to unregistered user wangguoz@gmail.com