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/10/12 22:26:39 UTC

Build failed in Jenkins: kafka-trunk-jdk11 #29

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

Changes:

[wangguoz] KAFKA-7223: Add late-record metrics (#5742)

------------------------------------------
[...truncated 1.29 MB...]
                          ^
<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:140: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:165: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:181: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:182: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:195: class ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:195: class ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:197: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:197: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:210: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:213: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:218: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:218: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:219: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:228: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:229: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:236: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:265: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/security/auth/ZkAuthorizationTest.scala>:283: class ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/server/KafkaApisTest.scala>:120: 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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/server/RequestQuotaTest.scala>:244: 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-trunk-jdk11/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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/tools/ConsoleProducerTest.scala>:66: method newInstance in class Class is deprecated: see corresponding Javadoc for more information.
    val reader = Class.forName(config.readerClass).newInstance().asInstanceOf[LineMessageReader]
                                                   ^
<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/src/test/scala/unit/kafka/tools/MirrorMakerTest.scala>:31: class BaseConsumerRecord in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val consumerRecord = BaseConsumerRecord("topic", 0, 1L, now, TimestampType.CREATE_TIME, "key".getBytes, "value".getBytes)
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/src/test/scala/unit/kafka/tools/MirrorMakerTest.scala>:46: class BaseConsumerRecord in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val consumerRecord = BaseConsumerRecord("topic", 0, 1L, RecordBatch.NO_TIMESTAMP, TimestampType.CREATE_TIME,
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/src/test/scala/unit/kafka/tools/MirrorMakerTest.scala>:63: class BaseConsumerRecord in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val consumerRecord = BaseConsumerRecord("topic", 0, 1L, now, TimestampType.CREATE_TIME, "key".getBytes,
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1116: class ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1123: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1123: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1130: class ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1133: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1148: class ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:31: class ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:36: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:99: object ZkUtils in package utils is deprecated (since 2.0.0): 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-trunk-jdk11/ws/core/src/test/scala/unit/kafka/utils/ZkUtilsTest.scala>:100: object ZkUtils in package utils is deprecated (since 2.0.0): 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"))
                                 ^
182 warnings found

> Task :core:processTestResources
> Task :core:testClasses
> Task :core:checkstyleTest NO-SOURCE

> Task :core:test

kafka.common.ZkNodeChangeNotificationListenerTest > testProcessNotification STARTED

kafka.common.ZkNodeChangeNotificationListenerTest > testProcessNotification PASSED

kafka.common.ZkNodeChangeNotificationListenerTest > testSwallowsProcessorException STARTED

kafka.common.ZkNodeChangeNotificationListenerTest > testSwallowsProcessorException PASSED
WARNING: An illegal reflective access operation has occurred
WARNING: Illegal reflective access by org.easymock.cglib.core.ReflectUtils$1 (file:/home/jenkins/.gradle/caches/modules-2/files-2.1/org.easymock/easymock/3.6/276883daaf2230e6f1e07c78ad695d2a18c7170b/easymock-3.6.jar) to method java.lang.ClassLoader.defineClass(java.lang.String,byte[],int,int,java.security.ProtectionDomain)
WARNING: Please consider reporting this to the maintainers of org.easymock.cglib.core.ReflectUtils$1
WARNING: Use --illegal-access=warn to enable warnings of further illegal reflective access operations
WARNING: All illegal access operations will be denied in a future release

kafka.common.InterBrokerSendThreadTest > shouldCreateClientRequestAndSendWhenNodeIsReady STARTED

kafka.common.InterBrokerSendThreadTest > shouldCreateClientRequestAndSendWhenNodeIsReady PASSED

kafka.common.InterBrokerSendThreadTest > testFailingExpiredRequests STARTED

kafka.common.InterBrokerSendThreadTest > testFailingExpiredRequests PASSED

kafka.common.InterBrokerSendThreadTest > shouldCallCompletionHandlerWithDisconnectedResponseWhenNodeNotReady STARTED

kafka.common.InterBrokerSendThreadTest > shouldCallCompletionHandlerWithDisconnectedResponseWhenNodeNotReady PASSED

kafka.common.InterBrokerSendThreadTest > shouldNotSendAnythingWhenNoRequests STARTED

kafka.common.InterBrokerSendThreadTest > shouldNotSendAnythingWhenNoRequests PASSED

kafka.KafkaTest > testKafkaSslPasswordsWithSymbols STARTED

kafka.KafkaTest > testKafkaSslPasswordsWithSymbols PASSED

kafka.KafkaTest > testKafkaSslPasswords STARTED

kafka.KafkaTest > testKafkaSslPasswords PASSED

kafka.KafkaTest > testGetKafkaConfigFromArgs STARTED

kafka.KafkaTest > testGetKafkaConfigFromArgs PASSED

kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsAtTheEnd STARTED

kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsAtTheEnd PASSED

kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsOnly STARTED

kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsOnly PASSED

kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsAtTheBegging STARTED

kafka.KafkaTest > testGetKafkaConfigFromArgsNonArgsAtTheBegging PASSED

kafka.api.LegacyAdminClientTest > testDescribeConsumerGroup STARTED

kafka.api.LegacyAdminClientTest > testDescribeConsumerGroup PASSED

kafka.api.LegacyAdminClientTest > testListGroups STARTED

kafka.api.LegacyAdminClientTest > testListGroups PASSED

kafka.api.LegacyAdminClientTest > testListAllBrokerVersionInfo STARTED

kafka.api.LegacyAdminClientTest > testListAllBrokerVersionInfo PASSED

kafka.api.LegacyAdminClientTest > testOffsetsForTimesWhenOffsetNotFound STARTED

kafka.api.LegacyAdminClientTest > testOffsetsForTimesWhenOffsetNotFound PASSED

kafka.api.LegacyAdminClientTest > testDescribeConsumerGroupForNonExistentGroup STARTED

kafka.api.LegacyAdminClientTest > testDescribeConsumerGroupForNonExistentGroup PASSED

kafka.api.LegacyAdminClientTest > testGetConsumerGroupSummary STARTED
ERROR: Could not install GRADLE_4_8_1_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_4_8_1_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_4_8_1_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_4_8_1_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_4_8_1_HOME
java.lang.NullPointerException
ERROR: Could not install GRADLE_4_8_1_HOME
java.lang.NullPointerException
Build timed out (after 360 minutes). Marking the build as failed.
Build was aborted
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 rajinisivaram@googlemail.com
Not sending mail to unregistered user wangguoz@gmail.com

Jenkins build is back to normal : kafka-trunk-jdk11 #30

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