See 
<https://builds.apache.org/job/kafka-1.0-jdk7/75/display/redirect?page=changes>

Changes:

[ismael] MINOR: Update Scala 2.11 to 2.11.12

------------------------------------------
[...truncated 25.11 KB...]
        (topicPartition, new ListOffsetResponse.PartitionData(Errors.NONE, 
offsets.map(new JLong(_)).asJava))
                         ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:679:
 constructor PartitionData in class PartitionData is deprecated: see 
corresponding Javadoc for more information.
          (topicPartition, new 
ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:682:
 constructor PartitionData in class PartitionData is deprecated: see 
corresponding Javadoc for more information.
          (topicPartition, new 
ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:1009:
 class ZKGroupTopicDirs in package utils is deprecated: This class has been 
deprecated and will be removed in a future release.
              val topicDirs = new ZKGroupTopicDirs(offsetFetchRequest.groupId, 
topicPartition.topic)
                                  ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:122:
 object ConsumerConfig in package consumer is deprecated: This object has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerConfig instead.
  val ReplicaSocketTimeoutMs = ConsumerConfig.SocketTimeout
                               ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:123:
 object ConsumerConfig in package consumer is deprecated: This object has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerConfig instead.
  val ReplicaSocketReceiveBufferBytes = ConsumerConfig.SocketBufferSize
                                        ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:124:
 object ConsumerConfig in package consumer is deprecated: This object has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerConfig instead.
  val ReplicaFetchMaxBytes = ConsumerConfig.FetchSize
                             ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:210:
 value DEFAULT_SASL_ENABLED_MECHANISMS in object SaslConfigs is deprecated: see 
corresponding Javadoc for more information.
  val SaslEnabledMechanisms = SaslConfigs.DEFAULT_SASL_ENABLED_MECHANISMS
                                          ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:217:
 class PartitionData in object ListOffsetRequest is deprecated: see 
corresponding Javadoc for more information.
        val partitions = Map(topicPartition -> new 
ListOffsetRequest.PartitionData(earliestOrLatest, 1))
                                                                     ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:228:
 value offsets in class PartitionData is deprecated: see corresponding Javadoc 
for more information.
          partitionData.offsets.get(0)
                        ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:72:
 class OldConsumer in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
        new OldConsumer(conf.filterSpec, props)
            ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:76:
 class NewShinyConsumer in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
          new NewShinyConsumer(Option(conf.topicArg), conf.partitionArg, 
Option(conf.offsetArg), None, getNewConsumerProps(conf), timeoutMs)
              ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:78:
 class NewShinyConsumer in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
          new NewShinyConsumer(Option(conf.topicArg), None, None, 
Option(conf.whitelistArg), getNewConsumerProps(conf), timeoutMs)
              ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:112:
 trait BaseConsumer in package consumer is deprecated: This trait has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
  def addShutdownHook(consumer: BaseConsumer, conf: ConsumerConfig) {
                                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:126:
 trait BaseConsumer in package consumer is deprecated: This trait has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
  def process(maxMessages: Integer, formatter: MessageFormatter, consumer: 
BaseConsumer, output: PrintStream, skipMessageOnError: Boolean) {
                                                                           ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:128:
 class BaseConsumerRecord in package consumer is deprecated: This class has 
been deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerRecord instead.
      val msg: BaseConsumerRecord = try {
               ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:196:
 object OffsetRequest in package api is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:231:
 object OffsetRequest in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
      (OffsetRequest.SmallestTimeString, OffsetRequest.LargestTimeString)
       ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:231:
 object OffsetRequest in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
      (OffsetRequest.SmallestTimeString, OffsetRequest.LargestTimeString)
                                         ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:360:
 class TopicFilter in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release.
    var filterSpec: TopicFilter = null
                    ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:397:
 class Blacklist in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:397:
 class Whitelist in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:426:
 object OffsetRequest in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
          case "earliest" => OffsetRequest.EarliestTime
                             ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:427:
 object OffsetRequest in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
          case "latest" => OffsetRequest.LatestTime
                           ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:438:
 object OffsetRequest in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
      else if (fromBeginning) OffsetRequest.EarliestTime
                              ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:439:
 object OffsetRequest in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
      else OffsetRequest.LatestTime
           ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:47:
 class OldProducer in package producer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:49:
 class NewShinyProducer in package producer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:77:
 class ConsumerConfig in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerConfig instead.
      val consumerConfig = new ConsumerConfig(config.props)
                               ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:78:
 trait ConsumerConnector in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:78:
 object Consumer in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:363:
 class KafkaStream in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:72:
 object ClientUtils in package client is deprecated: This class has been 
deprecated and will be removed in a future release.
    val metadataTargetBrokers = ClientUtils.parseBrokerList(brokerList)
                                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:79:
 object ClientUtils in package client is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:97:
 class SimpleConsumer in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
              val consumer = new SimpleConsumer(leader.host, leader.port, 
10000, 100000, clientId)
                                 ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/GetOffsetShell.scala>:99:
 object OffsetRequest in package api is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:324:
 class ConsumerConfig in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerConfig instead.
      val consumerConfig = new OldConsumerConfig(consumerConfigProps)
                               ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:325:
 class ZookeeperConsumerConnector in package consumer is deprecated: This class 
has been deprecated and will be removed in a future release.
      new ZookeeperConsumerConnector(consumerConfig)
          ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:330:
 class Whitelist in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release.
      new Whitelist(whitelist.get)
          ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:332:
 class Blacklist in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release.
      new Blacklist(blacklist.get)
          ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:504:
 trait BaseConsumer in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:512:
 class ZookeeperConsumerConnector in package consumer is deprecated: This class 
has been deprecated and will be removed in a future release.
  private class MirrorMakerOldConsumer(connector: ZookeeperConsumerConnector,
                                                  ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:513:
 class TopicFilter in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release.
                                       filterSpec: TopicFilter) extends 
MirrorMakerBaseConsumer {
                                                   ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:514:
 class ConsumerIterator in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:555:
 class BaseConsumerRecord in package consumer is deprecated: This class has 
been deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerRecord instead.
    override def receive() : BaseConsumerRecord = {
                             ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:630:
 class BaseConsumerRecord in package consumer is deprecated: This class has 
been deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerRecord instead.
    override def receive() : BaseConsumerRecord = {
                             ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:639:
 class ConsumerTimeoutException in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:698:
 class ConsumerThreadId in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:752:
 class BaseConsumerRecord in package consumer is deprecated: This class has 
been deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerRecord instead.
    def handle(record: BaseConsumerRecord): 
util.List[ProducerRecord[Array[Byte], Array[Byte]]]
                       ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:756:
 class BaseConsumerRecord in package consumer is deprecated: This class has 
been deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerRecord instead.
    override def handle(record: BaseConsumerRecord): 
util.List[ProducerRecord[Array[Byte], Array[Byte]]] = {
                                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:45:
 object OffsetRequest in package api is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:48:
 class ConsumerConfig in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.ConsumerConfig instead.
    val consumerConfig = new ConsumerConfig(consumerProps)
                             ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:49:
 trait ConsumerConnector in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:49:
 object Consumer in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplayLogProducer.scala>:124:
 class KafkaStream in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:77:
 object ConsumerConfig in package consumer is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:106:
 class Whitelist in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release.
    val topicWhiteListFiler = new Whitelist(regex)
                                  ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:124:
 object ClientUtils in package client is deprecated: This class has been 
deprecated and will be removed in a future release.
    val metadataTargetBrokers = ClientUtils.parseBrokerList(brokerList)
                                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:125:
 object ClientUtils in package client is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:237:
 class OffsetResponse in package api is deprecated: 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-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:246:
 class SimpleConsumer in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
      val consumer = new SimpleConsumer(broker.host, broker.port, 10000, 
100000, ReplicaVerificationTool.clientId)
                         ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:249:
 object OffsetRequest in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
      val offsetRequest = OffsetRequest(initialOffsetMap)
                          ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:347:
 class SimpleConsumer in package consumer is deprecated: This class has been 
deprecated and will be removed in a future release. Please use 
org.apache.kafka.clients.consumer.KafkaConsumer instead.
  val simpleConsumer = new SimpleConsumer(sourceBroker.host, sourceBroker.port, 
socketTimeout, socketBufferSize, ReplicaVerificationTool.clientId)
                           ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:348:
 class FetchRequestBuilder in package api is deprecated: This class has been 
deprecated and will be removed in a future release.
  val fetchRequestBuilder = new FetchRequestBuilder().
                                ^
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/core/src/main/scala/kafka/tools/ReplicaVerificationTool.scala>:366:
 class FetchResponse in package api is deprecated: This object has been 
deprecated and will be removed in a future release.
    var response: FetchResponse = null
                  ^
<https://builds.apache.org/job/kafka-1.0-jdk7/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-1.0-jdk7/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-1.0-jdk7/ws/core/src/main/scala/kafka/utils/ZkUtils.scala>:236:
 overriding method metricName in trait KafkaMetricsGroup of type (name: String, 
tags: scala.collection.Map[String,String])com.yammer.metrics.core.MetricName;
 method metricName has weaker access privileges; it should be at least 
protected[metrics]
  override protected def metricName(name: String, metricTags: 
scala.collection.Map[String, String]): MetricName = {
                         ^
<https://builds.apache.org/job/kafka-1.0-jdk7/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-1.0-jdk7/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-1.0-jdk7/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-1.0-jdk7/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"))
                                      ^
126 warnings found
one error found
:kafka-1.0-jdk7:core:compileScala FAILED
:test_core_2_11 FAILED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-1.0-jdk7:core:compileScala'.
> Compilation failed

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

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

BUILD FAILED in 1m 32s
16 actionable tasks: 13 executed, 3 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting 
GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
[FINDBUGS] Searching for all files in 
<https://builds.apache.org/job/kafka-1.0-jdk7/ws/> that match the pattern 
**/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting 
GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
Setting 
GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
<Git Blamer> Using GitBlamer to create author and commit information for all 
warnings.
<Git Blamer> GIT_COMMIT=64d064818d801251c4a2ca95d92d9b1ec8a1d0c9, 
workspace=<https://builds.apache.org/job/kafka-1.0-jdk7/ws/>
[FINDBUGS] Computing warning deltas based on reference build #73
Recording test results
Setting 
GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
ERROR: Step ?Publish JUnit test result report? failed: No test report files 
were found. Configuration error?
Setting 
GRADLE_3_4_RC_2_HOME=/home/jenkins/jenkins-slave/tools/hudson.plugins.gradle.GradleInstallation/Gradle_3.4-rc-2
Not sending mail to unregistered user ism...@juma.me.uk

Reply via email to