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 2019/04/27 01:19:03 UTC

Build failed in Jenkins: kafka-2.1-jdk8 #174

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

Changes:

[wangguoz] KAFKA-8254: Pass Changelog as Topic in Suppress Serdes (#6602) (#6641)

------------------------------------------
[...truncated 696.02 KB...]
      records = consumer.poll(100)
                         ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/api/PlaintextConsumerTest.scala>:1630: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      records = consumer.poll(100)
                         ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/api/PlaintextConsumerTest.scala>:1656: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      records = consumer.poll(100)
                         ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/api/PlaintextConsumerTest.scala>:1888: method poll in trait Consumer is deprecated: see corresponding Javadoc for more information.
      consumer.poll(50)
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/api/SaslPlainPlaintextConsumerTest.scala>:55: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val zkUtils = ZkUtils(zkConnect, zkSessionTimeout, zkConnectionTimeout, zkAclsEnabled.getOrElse(JaasUtils.isZkSecurityEnabled))
                  ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/api/SaslPlainSslEndToEndAuthorizationTest.scala>:137: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val zkUtils = ZkUtils(zkConnect, zkSessionTimeout, zkConnectionTimeout, zkAclsEnabled.getOrElse(JaasUtils.isZkSecurityEnabled))
                  ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:150: method close in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
    consumers.foreach(_.close(0, TimeUnit.MILLISECONDS))
                        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:1020: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      consumer.poll(1)
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:1053: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      received += consumer.poll(50).count
                           ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:1333: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
        assertEquals(0, consumer.poll(100).count)
                                 ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:1488: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
          val records = consumer.poll(50)
                                 ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/integration/kafka/server/MultipleListenersWithSameSecurityProtocolBaseTest.scala>:174: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
        records ++= consumer.poll(50).asScala
                             ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/other/kafka/ReplicationQuotasTestRig.scala>:141: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
      ReassignPartitionsCommand.executeAssignment(zkClient, None, ZkUtils.getReassignmentJson(newAssignment), Throttle(config.throttle))
                                                                  ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TestAdminUtils.scala>:22: trait AdminUtilities in package admin is deprecated: This class is deprecated and will be replaced by kafka.zk.AdminZkClient.
class TestAdminUtils extends AdminUtilities {
                             ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TestAdminUtils.scala>:23: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  override def changeBrokerConfig(zkUtils: ZkUtils, brokerIds: Seq[Int], configs: Properties): Unit = {}
                                           ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TestAdminUtils.scala>:24: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  override def fetchEntityConfig(zkUtils: ZkUtils, entityType: String, entityName: String): Properties = {new Properties}
                                          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TestAdminUtils.scala>:25: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  override def changeClientIdConfig(zkUtils: ZkUtils, clientId: String, configs: Properties): Unit = {}
                                             ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TestAdminUtils.scala>:26: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  override def changeUserOrUserClientIdConfig(zkUtils: ZkUtils, sanitizedEntityName: String, configs: Properties): Unit = {}
                                                       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TestAdminUtils.scala>:27: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  override def changeTopicConfig(zkUtils: ZkUtils, topic: String, configs: Properties): Unit = {}
                                          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TopicCommandTest.scala>:83: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val deletePath = getDeleteTopicPath(normalTopic)
                     ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/admin/TopicCommandTest.scala>:96: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val deleteOffsetTopicPath = getDeleteTopicPath(Topic.GROUP_METADATA_TOPIC_NAME)
                                ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:36: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  var zkUtils: ZkUtils = null
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:44: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    zkUtils = ZkUtils(zkConnect, zkSessionTimeout, zkConnectionTimeout, zkAclsEnabled.getOrElse(JaasUtils.isZkSecurityEnabled))
              ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:87: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
      if (ZkUtils.sensitivePath(path)) {
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:92: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
      } else if (!path.equals(ZkUtils.ConsumersPath)) {
                              ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:126: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val unsecureZkUtils = ZkUtils(zkConnect, 6000, 6000, false) 
                          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:140: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val unsecureZkUtils = ZkUtils(zkConnect, 6000, 6000, false)
                          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:165: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    for (path <- ZkUtils.SecureZkRootPaths) {
                 ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:181: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val unsecureZkUtils = ZkUtils(zkUrl, 6000, 6000, false)
                          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:182: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val secureZkUtils = ZkUtils(zkUrl, 6000, 6000, true)
                        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:195: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  private def testMigration(zkUrl: String, firstZk: ZkUtils, secondZk: ZkUtils) {
                                                    ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:195: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  private def testMigration(zkUrl: String, firstZk: ZkUtils, secondZk: ZkUtils) {
                                                                       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:197: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    for (path <- ZkUtils.SecureZkRootPaths ++ ZkUtils.SensitiveZkRootPaths) {
                 ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:197: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    for (path <- ZkUtils.SecureZkRootPaths ++ ZkUtils.SensitiveZkRootPaths) {
                                              ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:210: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
        firstZk.createPersistentPath(ZkUtils.ConsumersPath)
                                     ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:213: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
        secondZk.createPersistentPath(ZkUtils.ConsumersPath)
                                      ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:218: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    for (path <- ZkUtils.SecureZkRootPaths ++ ZkUtils.SensitiveZkRootPaths) {
                 ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:218: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    for (path <- ZkUtils.SecureZkRootPaths ++ ZkUtils.SensitiveZkRootPaths) {
                                              ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:219: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
      val sensitive = ZkUtils.sensitivePath(path)
                      ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:228: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val consumersAcl = firstZk.zkConnection.getAcl(ZkUtils.ConsumersPath).getKey
                                                   ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:229: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    assertTrue(ZkUtils.ConsumersPath, isAclCorrect(consumersAcl, false, false))
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:236: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val sensitive = ZkUtils.sensitivePath(path)
                    ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:265: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val unsecureZkUtils = ZkUtils(zkConnect, 6000, 6000, false)
                          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:283: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  private def deleteRecursive(zkUtils: ZkUtils, path: String): Try[Boolean] = {
                                       ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/KafkaApisTest.scala>:123: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
      val partitionOffsetCommitData = new OffsetCommitRequest.PartitionData(15L, 23, "")
                                      ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogDirFailureTest.scala>:143: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      consumer.poll(0).count() == 1
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogDirFailureTest.scala>:192: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      consumer.poll(0).count() > 0
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogDirFailureTest.scala>:207: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      consumer.poll(0)
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:58: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
        new ListOffsetRequest.PartitionData(ListOffsetRequest.LATEST_TIMESTAMP, 10)).asJava).build(0)
        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:90: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
        new ListOffsetRequest.PartitionData(ListOffsetRequest.LATEST_TIMESTAMP, 15)).asJava).build()
        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:91: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
    val consumerOffsets = sendListOffsetsRequest(request).responseData.get(topicPartition).offsets.asScala
                                                                                           ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:118: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
        new ListOffsetRequest.PartitionData(ListOffsetRequest.LATEST_TIMESTAMP, 15)).asJava).build()
        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:119: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
    val consumerOffsets = sendListOffsetsRequest(request).responseData.get(topicPartition).offsets.asScala
                                                                                           ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:146: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          new ListOffsetRequest.PartitionData(ListOffsetRequest.EARLIEST_TIMESTAMP, 1)).asJava).build()
          ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:147: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
      val consumerOffsets = sendListOffsetsRequest(request).responseData.get(topicPartition).offsets.asScala
                                                                                             ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:178: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
        new ListOffsetRequest.PartitionData(now, 15)).asJava).build()
        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:179: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
    val consumerOffsets = sendListOffsetsRequest(request).responseData.get(topicPartition).offsets.asScala
                                                                                           ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:205: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
        new ListOffsetRequest.PartitionData(ListOffsetRequest.EARLIEST_TIMESTAMP, 10)).asJava).build()
        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:206: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
    val consumerOffsets = sendListOffsetsRequest(request).responseData.get(topicPartition).offsets.asScala
                                                                                           ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/RequestQuotaTest.scala>:243: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
            Map(tp -> new OffsetCommitRequest.PartitionData(0, 15, "metadata")).asJava).
                      ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/server/epoch/EpochDrivenReplicationProtocolAcceptanceTest.scala>:242: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
    val records = consumer.poll(1000).asScala
                           ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1126: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  private def secureZkPaths(zkUtils: ZkUtils): Seq[String] = {
                                     ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1133: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val topLevelPaths = ZkUtils.SecureZkRootPaths ++ ZkUtils.SensitiveZkRootPaths
                        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1133: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val topLevelPaths = ZkUtils.SecureZkRootPaths ++ ZkUtils.SensitiveZkRootPaths
                                                     ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1140: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  def verifySecureZkAcls(zkUtils: ZkUtils, usersWithAccess: Int) {
                                  ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1143: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
        val sensitive = ZkUtils.sensitivePath(path)
                        ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1158: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  def verifyUnsecureZkAcls(zkUtils: ZkUtils) {
                                    ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:31: class ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
  var zkUtils: ZkUtils = _
               ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:36: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    zkUtils = ZkUtils(zkConnect, zkSessionTimeout, zkConnectionTimeout, zkAclsEnabled.getOrElse(JaasUtils.isZkSecurityEnabled))
              ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:99: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    zkUtils.createPersistentPath(ZkUtils.getTopicPartitionPath(topic, 0))
                                 ^
<https://builds.apache.org/job/kafka-2.1-jdk8/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:100: object ZkUtils in package utils is deprecated: This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    zkUtils.createPersistentPath(ZkUtils.getTopicPath("nopartitions"))
                                 ^
154 warnings found

> Task :core:processTestResources UP-TO-DATE
> Task :core:testClasses
> Task :connect:api:compileJava UP-TO-DATE
> Task :connect:api:processResources NO-SOURCE
> Task :connect:api:classes UP-TO-DATE
> Task :testScala_2_12 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-2.1-jdk8:core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-2.1-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 2h 4m 14s
50 actionable tasks: 20 executed, 30 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.1-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=bc51d803478e90af62d242ad8cc6cdaf348d3c17, workspace=<https://builds.apache.org/job/kafka-2.1-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #173
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user wangguoz@gmail.com

Jenkins build is back to normal : kafka-2.1-jdk8 #176

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


Build failed in Jenkins: kafka-2.1-jdk8 #175

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

Changes:

[matthias] MINOR: improve Session expiration notice (#6618)

------------------------------------------
[...truncated 919.52 KB...]
kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > logsShouldNotDivergeOnUncleanLeaderElections STARTED

kafka.server.epoch.EpochDrivenReplicationProtocolAcceptanceTest > logsShouldNotDivergeOnUncleanLeaderElections PASSED

kafka.server.epoch.LeaderEpochIntegrationTest > shouldIncreaseLeaderEpochBetweenLeaderRestarts STARTED

kafka.server.epoch.LeaderEpochIntegrationTest > shouldIncreaseLeaderEpochBetweenLeaderRestarts PASSED

kafka.server.epoch.LeaderEpochIntegrationTest > shouldAddCurrentLeaderEpochToMessagesAsTheyAreWrittenToLeader STARTED

kafka.server.epoch.LeaderEpochIntegrationTest > shouldAddCurrentLeaderEpochToMessagesAsTheyAreWrittenToLeader PASSED

kafka.server.epoch.LeaderEpochIntegrationTest > shouldSendLeaderEpochRequestAndGetAResponse STARTED

kafka.server.epoch.LeaderEpochIntegrationTest > shouldSendLeaderEpochRequestAndGetAResponse 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.ListOffsetsRequestTest > testListOffsetsErrorCodes STARTED

kafka.server.ListOffsetsRequestTest > testListOffsetsErrorCodes PASSED

kafka.server.ListOffsetsRequestTest > testCurrentEpochValidation STARTED

kafka.server.ListOffsetsRequestTest > testCurrentEpochValidation PASSED

kafka.server.DelayedOperationTest > testRequestPurge STARTED

kafka.server.DelayedOperationTest > testRequestPurge PASSED

kafka.server.DelayedOperationTest > testRequestExpiry STARTED

kafka.server.DelayedOperationTest > testRequestExpiry PASSED

kafka.server.DelayedOperationTest > shouldReturnNilOperationsOnCancelForKeyWhenKeyDoesntExist STARTED

kafka.server.DelayedOperationTest > shouldReturnNilOperationsOnCancelForKeyWhenKeyDoesntExist PASSED

kafka.server.DelayedOperationTest > testDelayedOperationLockOverride STARTED

kafka.server.DelayedOperationTest > testDelayedOperationLockOverride PASSED

kafka.server.DelayedOperationTest > testTryCompleteLockContention STARTED

kafka.server.DelayedOperationTest > testTryCompleteLockContention PASSED

kafka.server.DelayedOperationTest > testTryCompleteWithMultipleThreads STARTED

kafka.server.DelayedOperationTest > testTryCompleteWithMultipleThreads PASSED

kafka.server.DelayedOperationTest > shouldCancelForKeyReturningCancelledOperations STARTED

kafka.server.DelayedOperationTest > shouldCancelForKeyReturningCancelledOperations PASSED

kafka.server.DelayedOperationTest > testRequestSatisfaction STARTED

kafka.server.DelayedOperationTest > testRequestSatisfaction PASSED

kafka.server.DelayedOperationTest > testDelayedOperationLock STARTED

kafka.server.DelayedOperationTest > testDelayedOperationLock PASSED

kafka.server.OffsetsForLeaderEpochRequestTest > testOffsetsForLeaderEpochErrorCodes STARTED

kafka.server.OffsetsForLeaderEpochRequestTest > testOffsetsForLeaderEpochErrorCodes PASSED

kafka.server.OffsetsForLeaderEpochRequestTest > testCurrentEpochValidation STARTED

kafka.server.OffsetsForLeaderEpochRequestTest > testCurrentEpochValidation PASSED

kafka.network.DynamicConnectionQuotaTest > testDynamicConnectionQuota STARTED

kafka.network.DynamicConnectionQuotaTest > testDynamicConnectionQuota PASSED

kafka.network.SocketServerTest > testGracefulClose STARTED

kafka.network.SocketServerTest > testGracefulClose PASSED

kafka.network.SocketServerTest > testSendActionResponseWithThrottledChannelWhereThrottlingAlreadyDone STARTED

kafka.network.SocketServerTest > testSendActionResponseWithThrottledChannelWhereThrottlingAlreadyDone PASSED

kafka.network.SocketServerTest > controlThrowable STARTED

kafka.network.SocketServerTest > controlThrowable PASSED

kafka.network.SocketServerTest > testRequestMetricsAfterStop STARTED

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 > testSendActionResponseWithThrottledChannelWhereThrottlingInProgress STARTED

kafka.network.SocketServerTest > testSendActionResponseWithThrottledChannelWhereThrottlingInProgress PASSED

kafka.network.SocketServerTest > testIdleConnection STARTED

kafka.network.SocketServerTest > testIdleConnection PASSED

kafka.network.SocketServerTest > testClientDisconnectionWithStagedReceivesFullyProcessed STARTED

kafka.network.SocketServerTest > testClientDisconnectionWithStagedReceivesFullyProcessed PASSED

kafka.network.SocketServerTest > testZeroMaxConnectionsPerIp STARTED

kafka.network.SocketServerTest > testZeroMaxConnectionsPerIp 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 > testNoOpActionResponseWithThrottledChannelWhereThrottlingAlreadyDone STARTED

kafka.network.SocketServerTest > testNoOpActionResponseWithThrottledChannelWhereThrottlingAlreadyDone 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.network.SocketServerTest > testNoOpActionResponseWithThrottledChannelWhereThrottlingInProgress STARTED

kafka.network.SocketServerTest > testNoOpActionResponseWithThrottledChannelWhereThrottlingInProgress PASSED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate STARTED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate PASSED

2165 tests completed, 1 failed, 4 skipped

> Task :kafka-2.1-jdk8:core:test FAILED
> Task :testScala_2_12 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-2.1-jdk8:core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-2.1-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 2h 22m 8s
27 actionable tasks: 4 executed, 23 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.1-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=b7ed3a0df44f62bc72e59cc01bf44550a5310b57, workspace=<https://builds.apache.org/job/kafka-2.1-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #173
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user wangguoz@gmail.com