You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@kafka.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2017/09/05 18:43:29 UTC

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

See <https://builds.apache.org/job/kafka-trunk-jdk8/1974/display/redirect>

------------------------------------------
[...truncated 86.33 KB...]
                                                          ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:70: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val request = OffsetRequest(
                  ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:99: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val offsets = server.apis.fetchOffsets(logManager, new TopicPartition(topic, part), OffsetRequest.LatestTime, 15)
                                                                                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:105: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
      Map(topicAndPartition -> PartitionOffsetRequestInfo(OffsetRequest.LatestTime, 15)),
                                                          ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:104: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val offsetRequest = OffsetRequest(
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:130: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val offsets = server.apis.fetchOffsets(logManager, new TopicPartition(topic, part), OffsetRequest.LatestTime, 15)
                                                                                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:136: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
      Map(topicAndPartition -> PartitionOffsetRequestInfo(OffsetRequest.LatestTime, 15)),
                                                          ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:135: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val offsetRequest = OffsetRequest(
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:144: class FetchRequestBuilder in package api is deprecated: This class has been deprecated and will be removed in a future release.
      new FetchRequestBuilder().addFetch(topic, 0, consumerOffsets.head, 300 * 1024).build())
          ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:164: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
        OffsetRequest(Map(topicAndPartition -> PartitionOffsetRequestInfo(OffsetRequest.EarliestTime, 1)))
                                                                          ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:164: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
        OffsetRequest(Map(topicAndPartition -> PartitionOffsetRequestInfo(OffsetRequest.EarliestTime, 1)))
        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:198: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val offsetRequest = OffsetRequest(Map(topicAndPartition -> PartitionOffsetRequestInfo(now, 15)), replicaId = 0)
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:219: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val offsets = server.apis.fetchOffsets(logManager, new TopicPartition(topic, part), OffsetRequest.EarliestTime, 10)
                                                                                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:226: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
      OffsetRequest(Map(topicAndPartition -> PartitionOffsetRequestInfo(OffsetRequest.EarliestTime, 10)))
                                                                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:226: object OffsetRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
      OffsetRequest(Map(topicAndPartition -> PartitionOffsetRequestInfo(OffsetRequest.EarliestTime, 10)))
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:46: class SimpleConsumer in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.KafkaConsumer instead.
  var simpleConsumer: SimpleConsumer = null
                      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:57: class SimpleConsumer in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.KafkaConsumer instead.
    simpleConsumer = new SimpleConsumer("localhost", TestUtils.boundPort(server), 1000000, 64*1024, "test-client")
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:58: object GroupCoordinatorRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val consumerMetadataRequest = GroupCoordinatorRequest(group)
                                  ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:85: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest = OffsetCommitRequest(group, immutable.Map(topicAndPartition -> OffsetAndMetadata(offset = 42L)))
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:91: object OffsetFetchRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val fetchRequest = OffsetFetchRequest(group, Seq(topicAndPartition))
                       ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:99: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest1 = OffsetCommitRequest(group, immutable.Map(topicAndPartition -> OffsetAndMetadata(
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:108: object OffsetFetchRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val fetchRequest1 = OffsetFetchRequest(group, Seq(topicAndPartition))
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:117: object OffsetFetchRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val fetchRequest2 = OffsetFetchRequest(group, Seq(unknownTopicAndPartition))
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:137: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest = OffsetCommitRequest("test-group", immutable.Map(
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:149: object OffsetFetchRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val fetchRequest = OffsetFetchRequest(group, Seq(
                       ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:201: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest = OffsetCommitRequest("test-group", immutable.Map(topicAndPartition -> OffsetAndMetadata(
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:209: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest1 = OffsetCommitRequest(group, immutable.Map(topicAndPartition -> OffsetAndMetadata(
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:225: object OffsetFetchRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val fetchRequest = OffsetFetchRequest(group, Seq(TopicAndPartition(topic, 0)))
                       ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:229: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest0 = OffsetCommitRequest(
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:238: object OffsetFetchRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val offsetFetchReq = OffsetFetchRequest(group, Seq(TopicAndPartition(topic, 0)), versionId = 0)
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:245: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest1 = OffsetCommitRequest(
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:256: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest2 = OffsetCommitRequest(
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:267: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest3 = OffsetCommitRequest(
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:279: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest4 = OffsetCommitRequest(
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:299: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest = OffsetCommitRequest(group, immutable.Map(
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:316: object OffsetCommitRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val commitRequest = OffsetCommitRequest(group, immutable.Map(topicPartition -> OffsetAndMetadata(offset = 42L)))
                        ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/OffsetCommitTest.scala>:327: object OffsetFetchRequest in package api is deprecated: This object has been deprecated and will be removed in a future release.
    val fetchRequest = OffsetFetchRequest(group, Seq(TopicAndPartition(topic, 0)))
                       ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/ServerShutdownTest.scala>:84: class SimpleConsumer in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.KafkaConsumer instead.
    val consumer = new SimpleConsumer(host, TestUtils.boundPort(server), 1000000, 64*1024, "")
                       ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/ServerShutdownTest.scala>:88: class FetchRequestBuilder in package api is deprecated: This class has been deprecated and will be removed in a future release.
      val fetched = consumer.fetch(new FetchRequestBuilder().addFetch(topic, 0, 0, 10000).maxWait(0).build())
                                       ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/server/ServerShutdownTest.scala>:99: class FetchRequestBuilder in package api is deprecated: This class has been deprecated and will be removed in a future release.
      val fetched = consumer.fetch(new FetchRequestBuilder().addFetch(topic, 0, newOffset, 10000).build())
                                       ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/tools/ConsoleConsumerTest.scala>:39: class BaseConsumerRecord in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val record = new BaseConsumerRecord(topic = "foo", partition = 1, offset = 1, key = Array[Byte](), value = Array[Byte]())
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/tools/ConsoleConsumerTest.scala>:61: class BaseConsumerRecord in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val record = new BaseConsumerRecord(topic = "foo", partition = 1, offset = 1, key = Array[Byte](), value = Array[Byte]())
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:69: side-effecting nullary methods are discouraged: suggest defining as `def testAsJsonObject()` instead
  def testAsJsonObject: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:77: side-effecting nullary methods are discouraged: suggest defining as `def testAsJsonObjectOption()` instead
  def testAsJsonObjectOption: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:84: side-effecting nullary methods are discouraged: suggest defining as `def testAsJsonArray()` instead
  def testAsJsonArray: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:92: side-effecting nullary methods are discouraged: suggest defining as `def testAsJsonArrayOption()` instead
  def testAsJsonArrayOption: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:99: side-effecting nullary methods are discouraged: suggest defining as `def testJsonObjectGet()` instead
  def testJsonObjectGet: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:106: side-effecting nullary methods are discouraged: suggest defining as `def testJsonObjectApply()` instead
  def testJsonObjectApply: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:113: side-effecting nullary methods are discouraged: suggest defining as `def testJsonObjectIterator()` instead
  def testJsonObjectIterator: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:121: side-effecting nullary methods are discouraged: suggest defining as `def testJsonArrayIterator()` instead
  def testJsonArrayIterator: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:126: side-effecting nullary methods are discouraged: suggest defining as `def testJsonValueEquals()` instead
  def testJsonValueEquals: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:142: side-effecting nullary methods are discouraged: suggest defining as `def testJsonValueHashCode()` instead
  def testJsonValueHashCode: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:147: side-effecting nullary methods are discouraged: suggest defining as `def testJsonValueToString()` instead
  def testJsonValueToString: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:153: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeBoolean()` instead
  def testDecodeBoolean: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:159: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeString()` instead
  def testDecodeString: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:167: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeInt()` instead
  def testDecodeInt: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:173: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeLong()` instead
  def testDecodeLong: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:180: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeDouble()` instead
  def testDecodeDouble: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:188: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeSeq()` instead
  def testDecodeSeq: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:196: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeMap()` instead
  def testDecodeMap: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/utils/json/JsonValueTest.scala>:204: side-effecting nullary methods are discouraged: suggest defining as `def testDecodeOption()` instead
  def testDecodeOption: Unit = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKEphemeralTest.scala>:76: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnect, "test", "1"))
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:34: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnectWithInvalidRoot,
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:50: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnect, "test", "1"))
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:60: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnectWithInvalidRoot, "test", "1"))
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:74: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnect, "test", "1"))
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:84: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnectWithInvalidRoot, "test", "1"))
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:98: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnect, "test", "1"))
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:108: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnectWithInvalidRoot,
                     ^
<https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/test/scala/unit/kafka/zk/ZKPathTest.scala>:123: class ConsumerConfig in package consumer is deprecated: This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val config = new ConsumerConfig(TestUtils.createConsumerProperties(zkConnect, "test", "1"))
                     ^
164 warnings found
:kafka-trunk-jdk8:core:processTestResources
:kafka-trunk-jdk8:core:testClasses
:kafka-trunk-jdk8:core:checkstyleTest NO-SOURCE
:kafka-trunk-jdk8:core:findbugsMain
Scanning archives (0 / 15)Scanning archives (1 / 15)Scanning archives (2 / 15)Scanning archives (3 / 15)Scanning archives (4 / 15)Scanning archives (5 / 15)Scanning archives (6 / 15)Scanning archives (7 / 15)Scanning archives (8 / 15)Scanning archives (9 / 15)Scanning archives (10 / 15)Scanning archives (11 / 15)Scanning archives (12 / 15)Scanning archives (13 / 15)Scanning archives (14 / 15)Scanning archives (15 / 15)
2 analysis passes to perform
:kafka-trunk-jdk8:core:findbugsMain FAILED
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-trunk-jdk8:core:findbugsMain'.
> Failed to run Gradle FindBugs Worker
   > Process 'Gradle FindBugs Worker 3' finished with non-zero exit value 1

* Try:
Run with --stacktrace option to get the stack trace. Run with --info or --debug option to get more log output.

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

BUILD FAILED in 3m 40s
16 actionable tasks: 3 executed, 13 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-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] Skipping file  of module <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/build/reports/findbugs/main.xml> because it's empty.
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=d78eb03fad33b6060f246ae31c9276038e8555ec, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #1971
Recording test results
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
ERROR: Step ‘Publish JUnit test result report’ failed: No test report files were found. Configuration error?
Setting GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
Not sending mail to unregistered user damian.guy@gmail.com
Not sending mail to unregistered user wangguoz@gmail.com

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

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