See <https://builds.apache.org/job/kafka-trunk-jdk8/2634/display/redirect?page=changes>
Changes: [wangguoz] KAFKA-6878 Switch the order of underlying.init and initInternal (#4988) [github] KAFKA-6813: Remove deprecated APIs in KIP-182, Part II (#4976) [junrao] KAFKA-6361: Fix log divergence between leader and follower after fast ------------------------------------------ [...truncated 24.98 KB...] <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:126: 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-trunk-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:127: 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-trunk-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:128: 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-trunk-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:219: 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-trunk-jdk8/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:244: 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-trunk-jdk8/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:255: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information. partitionData.offsets.get(0) ^ <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:73: 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-trunk-jdk8/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), conf.partitionArg, Option(conf.offsetArg), None, consumer, timeoutMs) ^ <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:80: 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), consumer, timeoutMs) ^ <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:114: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:128: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:130: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:198: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:230: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:230: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:369: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:407: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:407: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:436: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:437: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:448: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:449: 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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/ConsumerPerformance.scala>:361: 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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:508: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:516: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:517: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:518: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:559: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:634: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:643: 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-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:702: 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-trunk-jdk8/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. def handle(record: BaseConsumerRecord): util.List[ProducerRecord[Array[Byte], Array[Byte]]] ^ <https://builds.apache.org/job/kafka-trunk-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:760: 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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-trunk-jdk8/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-jdk8/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-jdk8/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-jdk8/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-jdk8/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-jdk8/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")) ^ No space left on device 114 warnings found one error found :kafka-trunk-jdk8:core:compileScala FAILED :test_core_2_11 FAILED FAILURE: Build failed with an exception. * What went wrong: Execution failed for task ':kafka-trunk-jdk8: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. Run with --scan to get full insights. * Get more help at https://help.gradle.org BUILD FAILED in 1m 19s 24 actionable tasks: 23 executed, 1 up-to-date FAILURE: Build failed with an exception. * What went wrong: Could not add entry ':core:compileScala' to cache taskHistory.bin (<https://builds.apache.org/job/kafka-trunk-jdk8/ws/.gradle/4.5.1/taskHistory/taskHistory.bin).> > java.io.IOException: No space left on device * 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 1m 20s Build step 'Execute shell' marked build as failure [FINDBUGS] Collecting findbugs analysis files... Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4 [FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-trunk-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml [FINDBUGS] No files found. Configuration error? Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4 Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4 <Git Blamer> Using GitBlamer to create author and commit information for all warnings. <Git Blamer> GIT_COMMIT=9679c44d2b521b5c627e7bde375c0883f5857e0c, workspace=<https://builds.apache.org/job/kafka-trunk-jdk8/ws/> [FINDBUGS] Computing warning deltas based on reference build #2633 Recording test results Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4 ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error? Setting GRADLE_4_4_HOME=/home/jenkins/tools/gradle/4.4 Not sending mail to unregistered user wangg...@gmail.com Not sending mail to unregistered user git...@alasdairhodge.co.uk