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/01/28 02:49:51 UTC

Build failed in Jenkins: kafka-trunk-jdk9 #339

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

Changes:

[jason] MINOR: Fix Javadoc Issues (#4190)

------------------------------------------
[...truncated 1.07 MB...]
                                                                           ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:128: 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 msg: BaseConsumerRecord = try {
               ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:196: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
      val resetToBeginning = OffsetRequest.SmallestTimeString == props.getProperty(ConsumerConfig.AUTO_OFFSET_RESET_CONFIG)
                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:231: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
      (OffsetRequest.SmallestTimeString, OffsetRequest.LargestTimeString)
       ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:231: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
      (OffsetRequest.SmallestTimeString, OffsetRequest.LargestTimeString)
                                         ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:360: class TopicFilter in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
    var filterSpec: TopicFilter = null
                    ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:378: method newInstance in class Class is deprecated: see corresponding Javadoc for more information.
    val formatter: MessageFormatter = messageFormatterClass.newInstance().asInstanceOf[MessageFormatter]
                                                            ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:397: class Blacklist in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
      filterSpec = if (options.has(blacklistOpt)) new Blacklist(topicArg) else new Whitelist(topicArg)
                                                      ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:397: class Whitelist in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
      filterSpec = if (options.has(blacklistOpt)) new Blacklist(topicArg) else new Whitelist(topicArg)
                                                                                   ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:426: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
          case "earliest" => OffsetRequest.EarliestTime
                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:427: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
          case "latest" => OffsetRequest.LatestTime
                           ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:438: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
      else if (fromBeginning) OffsetRequest.EarliestTime
                              ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:439: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
      else OffsetRequest.LatestTime
           ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:527: method newInstance in class Class is deprecated: see corresponding Javadoc for more information.
      keyDeserializer = Some(Class.forName(props.getProperty("key.deserializer")).newInstance().asInstanceOf[Deserializer[_]])
                                                                                  ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:530: method newInstance in class Class is deprecated: see corresponding Javadoc for more information.
      valueDeserializer = Some(Class.forName(props.getProperty("value.deserializer")).newInstance().asInstanceOf[Deserializer[_]])
                                                                                      ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:42: method newInstance in class Class is deprecated: see corresponding Javadoc for more information.
        val reader = Class.forName(config.readerClass).newInstance().asInstanceOf[MessageReader]
                                                       ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:47: class OldProducer in package producer is deprecated (since 0.10.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.producer.KafkaProducer instead.
            new OldProducer(getOldProducerProps(config))
                ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:49: class NewShinyProducer in package producer is deprecated (since 0.10.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.producer.KafkaProducer instead.
            new NewShinyProducer(getNewProducerProps(config))
                ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:77: class ConsumerConfig 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.ConsumerConfig instead.
      val consumerConfig = new ConsumerConfig(config.props)
                               ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:78: trait ConsumerConnector in package consumer is deprecated (since 0.11.0.0): This trait has been deprecated and will be removed in a future release.
      val consumerConnector: ConsumerConnector = Consumer.create(consumerConfig)
                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:78: object Consumer in package consumer is deprecated (since 0.11.0.0): This object has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.Consumer instead.
      val consumerConnector: ConsumerConnector = Consumer.create(consumerConfig)
                                                 ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:363: class KafkaStream 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.streams.KafkaStreams instead.
                           stream: KafkaStream[Array[Byte], Array[Byte]],
                                   ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:72: object ClientUtils in package client is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
    val metadataTargetBrokers = ClientUtils.parseBrokerList(brokerList)
                                ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:79: object ClientUtils in package client is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
    val topicsMetadata = ClientUtils.fetchTopicMetadata(Set(topic), metadataTargetBrokers, clientId, maxWaitMs).topicsMetadata
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:97: class SimpleConsumer 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.KafkaConsumer instead.
              val consumer = new SimpleConsumer(leader.host, leader.port, 10000, 100000, clientId)
                                 ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:99: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
              val request = OffsetRequest(Map(topicAndPartition -> PartitionOffsetRequestInfo(time, nOffsets)))
                            ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:324: class ConsumerConfig 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.ConsumerConfig instead.
      val consumerConfig = new OldConsumerConfig(consumerConfigProps)
                               ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:325: class ZookeeperConsumerConnector in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
      new ZookeeperConsumerConnector(consumerConfig)
          ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:330: class Whitelist in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
      new Whitelist(whitelist.get)
          ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:332: class Blacklist in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
      new Blacklist(blacklist.get)
          ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:508: trait BaseConsumer in package consumer is deprecated (since 0.11.0.0): This trait has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.KafkaConsumer instead.
  private[kafka] trait MirrorMakerBaseConsumer extends BaseConsumer {
                                                       ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:516: class ZookeeperConsumerConnector in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
  private class MirrorMakerOldConsumer(connector: ZookeeperConsumerConnector,
                                                  ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:517: class TopicFilter in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
                                       filterSpec: TopicFilter) extends MirrorMakerBaseConsumer {
                                                   ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:518: class ConsumerIterator in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
    private var iter: ConsumerIterator[Array[Byte], Array[Byte]] = null
                      ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:559: 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.
    override def receive() : BaseConsumerRecord = {
                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:561: 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.
      BaseConsumerRecord(messageAndMetadata.topic,
      ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:611: class Whitelist in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
          consumer.subscribe(Pattern.compile(Whitelist(whitelist).regex), consumerRebalanceListener)
                                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:634: 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.
    override def receive() : BaseConsumerRecord = {
                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:643: class ConsumerTimeoutException 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.common.errors.TimeoutException instead.
          throw new ConsumerTimeoutException
                    ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:651: 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.
      BaseConsumerRecord(record.topic,
      ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:702: class ConsumerThreadId in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
                                        partitionAssignment: java.util.Map[String, java.util.Map[java.lang.Integer, ConsumerThreadId]]) {
                                                                       ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:756: 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.
    def handle(record: BaseConsumerRecord): util.List[ProducerRecord[Array[Byte], Array[Byte]]]
                       ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:760: 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.
    override def handle(record: BaseConsumerRecord): util.List[ProducerRecord[Array[Byte], Array[Byte]]] = {
                                ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:45: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
    consumerProps.put("auto.offset.reset", OffsetRequest.SmallestTimeString)
                                           ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:48: class ConsumerConfig 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.ConsumerConfig instead.
    val consumerConfig = new ConsumerConfig(consumerProps)
                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:49: trait ConsumerConnector in package consumer is deprecated (since 0.11.0.0): This trait has been deprecated and will be removed in a future release.
    val consumerConnector: ConsumerConnector = Consumer.create(consumerConfig)
                           ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:49: object Consumer in package consumer is deprecated (since 0.11.0.0): This object has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.Consumer instead.
    val consumerConnector: ConsumerConnector = Consumer.create(consumerConfig)
                                               ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:124: class KafkaStream 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.streams.KafkaStreams instead.
  class ZKConsumerThread(config: Config, stream: KafkaStream[Array[Byte], Array[Byte]]) extends Thread with Logging {
                                                 ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:77: object ConsumerConfig in package consumer is deprecated (since 0.11.0.0): This object has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerConfig instead.
                         .defaultsTo(ConsumerConfig.FetchSize)
                                     ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:106: class Whitelist in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
    val topicWhiteListFiler = new Whitelist(regex)
                                  ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:124: object ClientUtils in package client is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
    val metadataTargetBrokers = ClientUtils.parseBrokerList(brokerList)
                                ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:125: object ClientUtils in package client is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
    val topicsMetadataResponse = ClientUtils.fetchTopicMetadata(Set[String](), metadataTargetBrokers, clientId, maxWaitMs)
                                 ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:237: class OffsetResponse in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
  private def offsetResponseStringWithError(offsetResponse: OffsetResponse): String = {
                                                            ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:246: class SimpleConsumer 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.KafkaConsumer instead.
      val consumer = new SimpleConsumer(broker.host, broker.port, 10000, 100000, ReplicaVerificationTool.clientId)
                         ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:249: object OffsetRequest in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
      val offsetRequest = OffsetRequest(initialOffsetMap)
                          ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:347: class SimpleConsumer 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.KafkaConsumer instead.
  val simpleConsumer = new SimpleConsumer(sourceBroker.host, sourceBroker.port, socketTimeout, socketBufferSize, ReplicaVerificationTool.clientId)
                           ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:348: class FetchRequestBuilder in package api is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release.
  val fetchRequestBuilder = new FetchRequestBuilder().
                                ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:366: class FetchResponse in package api is deprecated (since 1.0.0): This object has been deprecated and will be removed in a future release.
    var response: FetchResponse = null
                  ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/IteratorTemplate.scala>:50: non-nullary method overrides nullary method
  def hasNext: Boolean = {
      ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/Mx4jLoader.scala>:48: method newInstance in class Class is deprecated: see corresponding Javadoc for more information.
      val httpAdaptor = httpAdaptorClass.newInstance()
                                         ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/Mx4jLoader.scala>:56: method newInstance in class Class is deprecated: see corresponding Javadoc for more information.
      val xsltProcessor = xsltProcessorClass.newInstance()
                                             ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/ToolsUtils.scala>:55: method value in trait Metric is deprecated: see corresponding Javadoc for more information.
        (mergedKeyName, value.value())
                              ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/json/DecodeJson.scala>:50: constructor JsonMappingException in class JsonMappingException is deprecated: see corresponding Javadoc for more information.
        throw new JsonMappingException(x)
              ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/json/JsonObject.scala>:34: constructor JsonMappingException in class JsonMappingException is deprecated: see corresponding Javadoc for more information.
    get(name).getOrElse(throw new JsonMappingException(s"No such field exists: `$name`"))
                              ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/json/JsonValue.scala>:62: constructor JsonMappingException in class JsonMappingException is deprecated: see corresponding Javadoc for more information.
    asJsonObjectOption.getOrElse(throw new JsonMappingException(s"Expected JSON object, received $node"))
                                       ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/main/scala/kafka/utils/json/JsonValue.scala>:79: constructor JsonMappingException in class JsonMappingException is deprecated: see corresponding Javadoc for more information.
    asJsonArrayOption.getOrElse(throw new JsonMappingException(s"Expected JSON array, received $node"))
                                      ^
144 warnings found
warning: [options] bootstrap class path not set in conjunction with -source 1.7
Note: Some input files use or override a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
1 warning
:core:processResources NO-SOURCE
:core:classes
:core:checkstyleMain
:core:compileTestJava NO-SOURCE
:core:compileTestScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/test/scala/integration/kafka/api/DelegationTokenEndToEndAuthorizationTest.scala>:87: local var token in method createDelegationToken is never set: consider using immutable val
    var (error, token)  = adminClient.createToken(List())
                ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:371: ambiguous reference to overloaded definition,
both method putAll in class Properties of type (x$1: java.util.Map[_, _])Unit
and  method putAll in class Hashtable of type (x$1: java.util.Map[_ <: Object, _ <: Object])Unit
match argument types (java.util.Properties)
      newProps.putAll(props)
               ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:63: private setter of servers in class DynamicBrokerReconfigurationTest is never used
  private var servers = new ArrayBuffer[KafkaServer]
              ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/test/scala/unit/kafka/log/LogCleanerIntegrationTest.scala>:21: Unused import
import java.util
            ^
<https://builds.apache.org/job/kafka-trunk-jdk9/ws/core/src/test/scala/unit/kafka/log/LogCleanerIntegrationTest.scala>:242: local val appends in method cleanerConfigUpdateTest is never used
    val appends = writeDups(numKeys = 100, numDups = 3, log = log, codec = codec)
        ^
four warnings found
one error found
:core:compileTestScala FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':core:compileTestScala'.
> Compilation failed

* 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 5m 14s
27 actionable tasks: 21 executed, 6 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_4_3_HOME=/home/jenkins/tools/gradle/4.3
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_4_3_HOME=/home/jenkins/tools/gradle/4.3
Not sending mail to unregistered user github@alasdairhodge.co.uk

Jenkins build is back to normal : kafka-trunk-jdk9 #340

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