See
<https://builds.apache.org/job/kafka-0.11.0-jdk7/343/display/redirect?page=changes>
Changes:
[wangguoz] KAFKA-6118: Fix transient failure
------------------------------------------
[...truncated 9.42 KB...]
if(l == null)
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/ClientQuotaManager.scala>:202:
method round in class RichLong is deprecated: This is an integer type; there
is no reason to round it. Perhaps you meant to call this on a floating-point
value?
throttleTimeMs = throttleTime(clientMetric,
getQuotaMetricConfig(clientQuotaEntity.quota)).round.toInt
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:308:
class ZKGroupTopicDirs in package utils is deprecated: This class has been
deprecated and will be removed in a future release.
val topicDirs = new ZKGroupTopicDirs(offsetCommitRequest.groupId,
topicPartition.topic)
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:347:
value timestamp in class PartitionData is deprecated: see corresponding
Javadoc for more information.
if (partitionData.timestamp ==
OffsetCommitRequest.DEFAULT_TIMESTAMP)
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:350:
value timestamp in class PartitionData is deprecated: see corresponding
Javadoc for more information.
offsetRetention + partitionData.timestamp
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:650:
method offsetData in class ListOffsetRequest is deprecated: see corresponding
Javadoc for more information.
val (authorizedRequestInfo, unauthorizedRequestInfo) =
offsetRequest.offsetData.asScala.partition {
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:650:
class PartitionData in object ListOffsetRequest is deprecated: see
corresponding Javadoc for more information.
val (authorizedRequestInfo, unauthorizedRequestInfo) =
offsetRequest.offsetData.asScala.partition {
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:655:
constructor PartitionData in class PartitionData is deprecated: see
corresponding Javadoc for more information.
new ListOffsetResponse.PartitionData(Errors.UNKNOWN_TOPIC_OR_PARTITION,
List[JLong]().asJava)
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:680:
constructor PartitionData in class PartitionData is deprecated: see
corresponding Javadoc for more information.
(topicPartition, new ListOffsetResponse.PartitionData(Errors.NONE,
offsets.map(new JLong(_)).asJava))
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:687:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:690:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:1016:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:119:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:120:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:121:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaServer.scala>:474:
class BlockingChannel in package network is deprecated: This class has been
deprecated and will be removed in a future release.
var channel: BlockingChannel = null
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaServer.scala>:495:
class BlockingChannel in package network is deprecated: This class has been
deprecated and will be removed in a future release.
channel = new BlockingChannel(brokerEndPoint.host,
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaServer.scala>:497:
object BlockingChannel in package network is deprecated: This object has been
deprecated and will be removed in a future release.
BlockingChannel.UseDefaultBufferSize,
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/KafkaServer.scala>:498:
object BlockingChannel in package network is deprecated: This object has been
deprecated and will be removed in a future release.
BlockingChannel.UseDefaultBufferSize,
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:219:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:230:
value offsets in class PartitionData is deprecated: see corresponding Javadoc
for more information.
partitionData.offsets.get(0)
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:66:
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, getOldConsumerProps(conf))
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:70:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:72:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:106:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:120:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:122:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:308:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:345:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:345:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:46:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsoleProducer.scala>:48:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:79:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:80:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:80:
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-0.11.0-jdk7/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:274:
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 ConsumerPerfThread(threadId: Int, name: String, stream:
KafkaStream[Array[Byte], Array[Byte]],
^
<https://builds.apache.org/job/kafka-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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-0.11.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().
^
75 warnings found
Note:
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/main/scala/kafka/javaapi/consumer/ConsumerConnector.java>
uses or overrides a deprecated API.
Note: Recompile with -Xlint:deprecation for details.
:kafka-0.11.0-jdk7:core:processResources NO-SOURCE
:kafka-0.11.0-jdk7:core:classes
:kafka-0.11.0-jdk7:core:checkstyleMain
:kafka-0.11.0-jdk7:core:compileTestJava NO-SOURCE
:kafka-0.11.0-jdk7:core:compileTestScala<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/test/scala/integration/kafka/api/SaslEndToEndAuthorizationTest.scala>:29:
Invalid literal number
>>>>>>> 2d8918b... KAFKA-6118: Fix transient failure
>>>>>>> testTwoConsumersWithDifferentSaslCredentials
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/test/scala/integration/kafka/api/SaslEndToEndAuthorizationTest.scala>:29:
Invalid literal number
>>>>>>> 2d8918b... KAFKA-6118: Fix transient failure
>>>>>>> testTwoConsumersWithDifferentSaslCredentials
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/test/scala/integration/kafka/api/SaslEndToEndAuthorizationTest.scala>:24:
expected class or object definition
<<<<<<< HEAD
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/test/scala/integration/kafka/api/SaslEndToEndAuthorizationTest.scala>:26:
expected class or object definition
=======
^
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/core/src/test/scala/integration/kafka/api/SaslEndToEndAuthorizationTest.scala>:29:
expected class or object definition
>>>>>>> 2d8918b... KAFKA-6118: Fix transient failure
>>>>>>> testTwoConsumersWithDifferentSaslCredentials
^
5 errors found
FAILED
:test_core_2_11 FAILED
FAILURE: Build failed with an exception.
* What went wrong:
Execution failed for task ':kafka-0.11.0-jdk7: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.
BUILD FAILED
Total time: 1 mins 38.9 secs
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
[FINDBUGS] Searching for all files in
<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/> that match the pattern
**/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
<Git Blamer> Using GitBlamer to create author and commit information for all
warnings.
<Git Blamer> GIT_COMMIT=d2a95ec07ed258c819e74a259ac43f5a85826180,
workspace=<https://builds.apache.org/job/kafka-0.11.0-jdk7/ws/>
[FINDBUGS] Computing warning deltas based on reference build #340
Recording test results
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
ERROR: Step ?Publish JUnit test result report? failed: No test report files
were found. Configuration error?
ERROR: No tool found matching GRADLE_3_4_RC_2_HOME
Setting GRADLE_3_5_HOME=/home/jenkins/tools/gradle/3.5
Not sending mail to unregistered user [email protected]