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 2019/08/28 17:57:28 UTC

Build failed in Jenkins: kafka-2.3-jdk8 #97

See <https://builds.apache.org/job/kafka-2.3-jdk8/97/display/redirect?page=changes>

Changes:

[wangguoz] MINOR: Only send delete request if there are offsets in map (#7256)

------------------------------------------
[...truncated 59.58 KB...]
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:821: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
      new ListOffsetResponse.PartitionData(Errors.TOPIC_AUTHORIZATION_FAILED, List[JLong]().asJava)
      ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:829: value maxNumOffsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
          maxNumOffsets = partitionData.maxNumOffsets,
                                        ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:832: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
        (topicPartition, new ListOffsetResponse.PartitionData(Errors.NONE, offsets.map(JLong.valueOf).asJava))
                         ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:841: 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-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:844: 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-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:231: value DEFAULT_SASL_ENABLED_MECHANISMS in class SaslConfigs is deprecated: see corresponding Javadoc for more information.
  val SaslEnabledMechanisms = SaslConfigs.DEFAULT_SASL_ENABLED_MECHANISMS
                                          ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/ReplicaFetcherThread.scala>:235: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
          responsePartitionData.offsets.get(0)
                                ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/ConsoleConsumer.scala>:573: method checksum in class ConsumerRecord is deprecated: see corresponding Javadoc for more information.
    output.println(topicStr + "checksum:" + consumerRecord.checksum)
                                                           ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:197: 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.
    private def toBaseConsumerRecord(record: ConsumerRecord[Array[Byte], Array[Byte]]): BaseConsumerRecord =
                                                                                        ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:198: 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-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:417: 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-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:421: 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]]] = {
                                ^
34 warnings found
Note: <https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/StreamsResetter.java> uses unchecked or unsafe operations.
Note: Recompile with -Xlint:unchecked for details.

> Task :kafka-2.3-jdk8:core:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:core:classes
> Task :kafka-2.3-jdk8:core:checkstyleMain
> Task :kafka-2.3-jdk8:core:compileTestJava NO-SOURCE

> Task :kafka-2.3-jdk8:core:compileTestScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:370: value DEFAULT_TIMESTAMP in class OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
                  .setCommitTimestamp(OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                          ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/integration/UncleanLeaderElectionTest.scala>:21: Unused import
import org.junit.{After, Before, Ignore, Test}
                                 ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/log/LogManagerTest.scala>:386: local val log in method testCreateAndDeleteOverlyLongTopic is never used
    val log = logManager.getOrCreateLog(new TopicPartition(invalidTopicName, 0), logConfig)
        ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/server/RequestQuotaTest.scala>:17: Unused import
import java.nio.ByteBuffer
                ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AdminClientIntegrationTest.scala>:1621: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    var alterResult = client.alterConfigs(Map(
                             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AdminClientIntegrationTest.scala>:1653: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    alterResult = client.alterConfigs(Map(
                         ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AdminClientIntegrationTest.scala>:1693: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    var alterResult = client.alterConfigs(Map(
                             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AdminClientIntegrationTest.scala>:1721: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    alterResult = client.alterConfigs(Map(
                         ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AdminClientWithPoliciesIntegrationTest.scala>:125: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    var alterResult = client.alterConfigs(Map(
                             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AdminClientWithPoliciesIntegrationTest.scala>:155: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    alterResult = client.alterConfigs(Map(
                         ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:824: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
    consumer.poll(50)
             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:871: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
    consumer.poll(0)
             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:897: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
    consumer.poll(0)
             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/BaseProducerSendTest.scala>:122: method checksum in class RecordMetadata is deprecated: see corresponding Javadoc for more information.
          assertNotEquals(metadata.checksum(), 0)
                                   ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala>:100: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
      val records = consumer.poll(100).asScala
                             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/ConsumerBounceTest.scala>:394: method poll in class KafkaConsumer is deprecated: see corresponding Javadoc for more information.
          consumer.poll(0L)
                   ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:1211: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    adminClient.alterConfigs(configs).all.get
                ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/server/DynamicBrokerReconfigurationTest.scala>:1229: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    adminClients.head.alterConfigs(configs).all.get
                      ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/other/kafka/ReplicationQuotasTestRig.scala>:141: object ZkUtils in package utils is deprecated (since 2.0.0): This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
      ReassignPartitionsCommand.executeAssignment(zkClient, None, ZkUtils.getReassignmentJson(newAssignment), Throttle(config.throttle))
                                                                  ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/admin/PreferredReplicaLeaderElectionCommandTest.scala>:148: object ZkUtils in package utils is deprecated (since 2.0.0): This is an internal class that is no longer used by Kafka and will be removed in a future release. Please use org.apache.kafka.clients.admin.AdminClient instead.
    val jsonString = ZkUtils.preferredReplicaLeaderElectionZkData(partitions.map(new TopicAndPartition(_)))
                     ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/log/TransactionIndexTest.scala>:27: class JUnitSuite in package junit is deprecated: JUnitSuite has been moved from org.scalatest.junit to org.scalatestplus.junit. Please update your imports, as this deprecated type alias will be removed in a future version of ScalaTest.
class TransactionIndexTest extends JUnitSuite {
                                   ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/security/auth/AclTest.scala>:27: class JUnitSuite in package junit is deprecated: JUnitSuite has been moved from org.scalatest.junit to org.scalatestplus.junit. Please update your imports, as this deprecated type alias will be removed in a future version of ScalaTest.
class AclTest extends JUnitSuite {
                      ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/server/KafkaApisTest.scala>:513: side-effecting nullary methods are discouraged: suggest defining as `def testJoinGroupProtocolsOrder()` instead
  def testJoinGroupProtocolsOrder: Unit = {
      ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:120: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
        new ListOffsetRequest.PartitionData(ListOffsetRequest.LATEST_TIMESTAMP, 15)).asJava).build()
        ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:121: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
    val consumerOffsets = sendListOffsetsRequest(request).responseData.get(topicPartition).offsets.asScala
                                                                                           ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:148: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          new ListOffsetRequest.PartitionData(ListOffsetRequest.EARLIEST_TIMESTAMP, 1)).asJava).build()
          ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/server/LogOffsetTest.scala>:149: value offsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
      val consumerOffsets = sendListOffsetsRequest(request).responseData.get(topicPartition).offsets.asScala
                                                                                             ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/tools/MirrorMakerTest.scala>:31: class BaseConsumerRecord in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val consumerRecord = BaseConsumerRecord("topic", 0, 1L, now, TimestampType.CREATE_TIME, "key".getBytes, "value".getBytes)
                         ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/tools/MirrorMakerTest.scala>:46: class BaseConsumerRecord in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val consumerRecord = BaseConsumerRecord("topic", 0, 1L, RecordBatch.NO_TIMESTAMP, TimestampType.CREATE_TIME,
                         ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/tools/MirrorMakerTest.scala>:63: class BaseConsumerRecord in package consumer is deprecated (since 0.11.0.0): This class has been deprecated and will be removed in a future release. Please use org.apache.kafka.clients.consumer.ConsumerRecord instead.
    val consumerRecord = BaseConsumerRecord("topic", 0, 1L, now, TimestampType.CREATE_TIME, "key".getBytes,
                         ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1407: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    adminClient.alterConfigs(configs)
                ^
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/utils/TestUtils.scala>:1428: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    adminClient.alterConfigs(configs)
                ^
32 warnings found

> Task :kafka-2.3-jdk8:core:processTestResources UP-TO-DATE
> Task :kafka-2.3-jdk8:core:testClasses
> Task :kafka-2.3-jdk8:core:checkstyleTest NO-SOURCE
> Task :kafka-2.3-jdk8:spotlessScala UP-TO-DATE
> Task :kafka-2.3-jdk8:spotlessScalaCheck UP-TO-DATE
> Task :kafka-2.3-jdk8:core:copyDependantLibs
> Task :kafka-2.3-jdk8:core:jar
> Task :kafka-2.3-jdk8:connect:api:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:connect:api:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:connect:api:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:connect:api:copyDependantLibs UP-TO-DATE
> Task :kafka-2.3-jdk8:connect:api:jar UP-TO-DATE
> Task :kafka-2.3-jdk8:connect:json:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:connect:json:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:connect:json:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:connect:json:copyDependantLibs UP-TO-DATE
> Task :kafka-2.3-jdk8:connect:json:jar UP-TO-DATE
> Task :kafka-2.3-jdk8:streams:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:streams:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:streams:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:streams:copyDependantLibs
> Task :kafka-2.3-jdk8:streams:jar UP-TO-DATE
> Task :kafka-2.3-jdk8:streams:test-utils:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:streams:test-utils:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:streams:test-utils:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:streams:test-utils:copyDependantLibs
> Task :kafka-2.3-jdk8:streams:test-utils:jar UP-TO-DATE

> Task :kafka-2.3-jdk8:streams:compileTestJava
<https://builds.apache.org/job/kafka-2.3-jdk8/ws/streams/src/test/java/org/apache/kafka/streams/processor/internals/AssignedStreamsTasksTest.java>:511: error: no suitable constructor found for StreamTask(TaskId,Set<TopicPartition>,ProcessorTopology,MockConsumer<byte[],byte[]>,ChangelogReader,StreamsConfig,StreamsMetricsImpl,StateDirectory,<null>,MockTime,()->producer)
        final StreamTask task = new StreamTask(
                                ^
    constructor StreamTask.StreamTask(TaskId,Collection<TopicPartition>,ProcessorTopology,Consumer<byte[],byte[]>,ChangelogReader,StreamsConfig,StreamsMetricsImpl,StateDirectory,ThreadCache,Time,ProducerSupplier,Sensor) is not applicable
      (actual and formal argument lists differ in length)
    constructor StreamTask.StreamTask(TaskId,Collection<TopicPartition>,ProcessorTopology,Consumer<byte[],byte[]>,ChangelogReader,StreamsConfig,StreamsMetricsImpl,StateDirectory,ThreadCache,Time,ProducerSupplier,RecordCollector,Sensor) is not applicable
      (actual and formal argument lists differ in length)
1 error

> Task :kafka-2.3-jdk8:streams:compileTestJava FAILED
> Task :kafka-2.3-jdk8:core:spotbugsMain
The following classes needed for analysis were missing:
  org.apache.log4j.Logger
  org.apache.log4j.Level
  org.apache.log4j.LogManager

> Task :testScala_2_12 FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':streams:compileTestJava'.
> Compilation failed; see the compiler error output for details.

* 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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:streams:compileTestJava'.
> Compilation failed; see the compiler error output for details.

* 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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:streams:compileTestJava'.
> Compilation failed; see the compiler error output for details.

* 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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 8m 48s
68 actionable tasks: 42 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=f1244e508d6e25c2ee603578a0c897af235fc93a, workspace=<https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #94
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user wangguoz@gmail.com

Jenkins build is back to normal : kafka-2.3-jdk8 #103

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


Build failed in Jenkins: kafka-2.3-jdk8 #102

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

Changes:

[wangguoz] KAFKA-8816: Make offsets immutable to users of RecordCollector.offsets

------------------------------------------
[...truncated 2.78 MB...]
kafka.zk.KafkaZkClientTest > testSetAndGetConsumerOffset STARTED

kafka.zk.KafkaZkClientTest > testSetAndGetConsumerOffset PASSED

kafka.zk.KafkaZkClientTest > testClusterIdMethods STARTED

kafka.zk.KafkaZkClientTest > testClusterIdMethods PASSED

kafka.zk.KafkaZkClientTest > testEntityConfigManagementMethods STARTED

kafka.zk.KafkaZkClientTest > testEntityConfigManagementMethods PASSED

kafka.zk.KafkaZkClientTest > testUpdateLeaderAndIsr STARTED

kafka.zk.KafkaZkClientTest > testUpdateLeaderAndIsr PASSED

kafka.zk.KafkaZkClientTest > testUpdateBrokerInfo STARTED

kafka.zk.KafkaZkClientTest > testUpdateBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testCreateRecursive STARTED

kafka.zk.KafkaZkClientTest > testCreateRecursive PASSED

kafka.zk.KafkaZkClientTest > testGetConsumerOffsetNoData STARTED

kafka.zk.KafkaZkClientTest > testGetConsumerOffsetNoData PASSED

kafka.zk.KafkaZkClientTest > testDeleteTopicPathMethods STARTED

kafka.zk.KafkaZkClientTest > testDeleteTopicPathMethods PASSED

kafka.zk.KafkaZkClientTest > testSetTopicPartitionStatesRaw STARTED

kafka.zk.KafkaZkClientTest > testSetTopicPartitionStatesRaw PASSED

kafka.zk.KafkaZkClientTest > testAclManagementMethods STARTED

kafka.zk.KafkaZkClientTest > testAclManagementMethods PASSED

kafka.zk.KafkaZkClientTest > testPreferredReplicaElectionMethods STARTED

kafka.zk.KafkaZkClientTest > testPreferredReplicaElectionMethods PASSED

kafka.zk.KafkaZkClientTest > testPropagateLogDir STARTED

kafka.zk.KafkaZkClientTest > testPropagateLogDir PASSED

kafka.zk.KafkaZkClientTest > testGetDataAndStat STARTED

kafka.zk.KafkaZkClientTest > testGetDataAndStat PASSED

kafka.zk.KafkaZkClientTest > testReassignPartitionsInProgress STARTED

kafka.zk.KafkaZkClientTest > testReassignPartitionsInProgress PASSED

kafka.zk.KafkaZkClientTest > testCreateTopLevelPaths STARTED

kafka.zk.KafkaZkClientTest > testCreateTopLevelPaths PASSED

kafka.zk.KafkaZkClientTest > testIsrChangeNotificationGetters STARTED

kafka.zk.KafkaZkClientTest > testIsrChangeNotificationGetters PASSED

kafka.zk.KafkaZkClientTest > testLogDirEventNotificationsDeletion STARTED

kafka.zk.KafkaZkClientTest > testLogDirEventNotificationsDeletion PASSED

kafka.zk.KafkaZkClientTest > testGetLogConfigs STARTED

kafka.zk.KafkaZkClientTest > testGetLogConfigs PASSED

kafka.zk.KafkaZkClientTest > testBrokerSequenceIdMethods STARTED

kafka.zk.KafkaZkClientTest > testBrokerSequenceIdMethods PASSED

kafka.zk.KafkaZkClientTest > testAclMethods STARTED

kafka.zk.KafkaZkClientTest > testAclMethods PASSED

kafka.zk.KafkaZkClientTest > testCreateSequentialPersistentPath STARTED

kafka.zk.KafkaZkClientTest > testCreateSequentialPersistentPath PASSED

kafka.zk.KafkaZkClientTest > testConditionalUpdatePath STARTED

kafka.zk.KafkaZkClientTest > testConditionalUpdatePath PASSED

kafka.zk.KafkaZkClientTest > testDeleteTopicZNode STARTED

kafka.zk.KafkaZkClientTest > testDeleteTopicZNode PASSED

kafka.zk.KafkaZkClientTest > testDeletePath STARTED

kafka.zk.KafkaZkClientTest > testDeletePath PASSED

kafka.zk.KafkaZkClientTest > testGetBrokerMethods STARTED

kafka.zk.KafkaZkClientTest > testGetBrokerMethods PASSED

kafka.zk.KafkaZkClientTest > testCreateTokenChangeNotification STARTED

kafka.zk.KafkaZkClientTest > testCreateTokenChangeNotification PASSED

kafka.zk.KafkaZkClientTest > testGetTopicsAndPartitions STARTED

kafka.zk.KafkaZkClientTest > testGetTopicsAndPartitions PASSED

kafka.zk.KafkaZkClientTest > testRegisterBrokerInfo STARTED

kafka.zk.KafkaZkClientTest > testRegisterBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testRetryRegisterBrokerInfo STARTED

kafka.zk.KafkaZkClientTest > testRetryRegisterBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testConsumerOffsetPath STARTED

kafka.zk.KafkaZkClientTest > testConsumerOffsetPath PASSED

kafka.zk.KafkaZkClientTest > testDeleteRecursiveWithControllerEpochVersionCheck STARTED

kafka.zk.KafkaZkClientTest > testDeleteRecursiveWithControllerEpochVersionCheck PASSED

kafka.zk.KafkaZkClientTest > testControllerManagementMethods STARTED

kafka.zk.KafkaZkClientTest > testControllerManagementMethods PASSED

kafka.zk.KafkaZkClientTest > testTopicAssignmentMethods STARTED

kafka.zk.KafkaZkClientTest > testTopicAssignmentMethods PASSED

kafka.zk.KafkaZkClientTest > testPropagateIsrChanges STARTED

kafka.zk.KafkaZkClientTest > testPropagateIsrChanges PASSED

kafka.zk.KafkaZkClientTest > testControllerEpochMethods STARTED

kafka.zk.KafkaZkClientTest > testControllerEpochMethods PASSED

kafka.zk.KafkaZkClientTest > testDeleteRecursive STARTED

kafka.zk.KafkaZkClientTest > testDeleteRecursive PASSED

kafka.zk.KafkaZkClientTest > testGetTopicPartitionStates STARTED

kafka.zk.KafkaZkClientTest > testGetTopicPartitionStates PASSED

kafka.zk.KafkaZkClientTest > testCreateConfigChangeNotification STARTED

kafka.zk.KafkaZkClientTest > testCreateConfigChangeNotification PASSED

kafka.zk.KafkaZkClientTest > testDelegationTokenMethods STARTED

kafka.zk.KafkaZkClientTest > testDelegationTokenMethods PASSED

kafka.common.ZkNodeChangeNotificationListenerTest > testProcessNotification STARTED

kafka.common.ZkNodeChangeNotificationListenerTest > testProcessNotification PASSED

kafka.common.ZkNodeChangeNotificationListenerTest > testSwallowsProcessorException STARTED

kafka.common.ZkNodeChangeNotificationListenerTest > testSwallowsProcessorException PASSED

kafka.common.InterBrokerSendThreadTest > shouldCreateClientRequestAndSendWhenNodeIsReady STARTED

kafka.common.InterBrokerSendThreadTest > shouldCreateClientRequestAndSendWhenNodeIsReady PASSED

kafka.common.InterBrokerSendThreadTest > testFailingExpiredRequests STARTED

kafka.common.InterBrokerSendThreadTest > testFailingExpiredRequests PASSED

kafka.common.InterBrokerSendThreadTest > shouldCallCompletionHandlerWithDisconnectedResponseWhenNodeNotReady STARTED

kafka.common.InterBrokerSendThreadTest > shouldCallCompletionHandlerWithDisconnectedResponseWhenNodeNotReady PASSED

kafka.common.InterBrokerSendThreadTest > shouldNotSendAnythingWhenNoRequests STARTED

kafka.common.InterBrokerSendThreadTest > shouldNotSendAnythingWhenNoRequests PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] PASSED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate STARTED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate PASSED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':connect:runtime:test'.
> Process 'Gradle Test Executor 12' finished with non-zero exit value 1
  This problem might be caused by incorrect test process configuration.
  Please refer to the test execution section in the User Manual at https://docs.gradle.org/5.4.1/userguide/java_testing.html#sec:test_execution

* 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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/build/reports/tests/test/index.html>

* 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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 4h 58m 46s
134 actionable tasks: 108 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=29514bd45c8c2eadfb1bee112917ec0bbc68f884, workspace=<https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #94
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user bill@confluent.io
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-2.3-jdk8 #101

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

Changes:

[jason] KAFKA-8724; Improve range checking when computing cleanable partitions

------------------------------------------
[...truncated 2.96 MB...]

kafka.zk.KafkaZkClientTest > testSetGetAndDeletePartitionReassignment PASSED

kafka.zk.KafkaZkClientTest > testIsrChangeNotificationsDeletion STARTED

kafka.zk.KafkaZkClientTest > testIsrChangeNotificationsDeletion PASSED

kafka.zk.KafkaZkClientTest > testGetDataAndVersion STARTED

kafka.zk.KafkaZkClientTest > testGetDataAndVersion PASSED

kafka.zk.KafkaZkClientTest > testGetChildren STARTED

kafka.zk.KafkaZkClientTest > testGetChildren PASSED

kafka.zk.KafkaZkClientTest > testSetAndGetConsumerOffset STARTED

kafka.zk.KafkaZkClientTest > testSetAndGetConsumerOffset PASSED

kafka.zk.KafkaZkClientTest > testClusterIdMethods STARTED

kafka.zk.KafkaZkClientTest > testClusterIdMethods PASSED

kafka.zk.KafkaZkClientTest > testEntityConfigManagementMethods STARTED

kafka.zk.KafkaZkClientTest > testEntityConfigManagementMethods PASSED

kafka.zk.KafkaZkClientTest > testUpdateLeaderAndIsr STARTED

kafka.zk.KafkaZkClientTest > testUpdateLeaderAndIsr PASSED

kafka.zk.KafkaZkClientTest > testUpdateBrokerInfo STARTED

kafka.zk.KafkaZkClientTest > testUpdateBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testCreateRecursive STARTED

kafka.zk.KafkaZkClientTest > testCreateRecursive PASSED

kafka.zk.KafkaZkClientTest > testGetConsumerOffsetNoData STARTED

kafka.zk.KafkaZkClientTest > testGetConsumerOffsetNoData PASSED

kafka.zk.KafkaZkClientTest > testDeleteTopicPathMethods STARTED

kafka.zk.KafkaZkClientTest > testDeleteTopicPathMethods PASSED

kafka.zk.KafkaZkClientTest > testSetTopicPartitionStatesRaw STARTED

kafka.zk.KafkaZkClientTest > testSetTopicPartitionStatesRaw PASSED

kafka.zk.KafkaZkClientTest > testAclManagementMethods STARTED

kafka.zk.KafkaZkClientTest > testAclManagementMethods PASSED

kafka.zk.KafkaZkClientTest > testPreferredReplicaElectionMethods STARTED

kafka.zk.KafkaZkClientTest > testPreferredReplicaElectionMethods PASSED

kafka.zk.KafkaZkClientTest > testPropagateLogDir STARTED

kafka.zk.KafkaZkClientTest > testPropagateLogDir PASSED

kafka.zk.KafkaZkClientTest > testGetDataAndStat STARTED

kafka.zk.KafkaZkClientTest > testGetDataAndStat PASSED

kafka.zk.KafkaZkClientTest > testReassignPartitionsInProgress STARTED

kafka.zk.KafkaZkClientTest > testReassignPartitionsInProgress PASSED

kafka.zk.KafkaZkClientTest > testCreateTopLevelPaths STARTED

kafka.zk.KafkaZkClientTest > testCreateTopLevelPaths PASSED

kafka.zk.KafkaZkClientTest > testIsrChangeNotificationGetters STARTED

kafka.zk.KafkaZkClientTest > testIsrChangeNotificationGetters PASSED

kafka.zk.KafkaZkClientTest > testLogDirEventNotificationsDeletion STARTED

kafka.zk.KafkaZkClientTest > testLogDirEventNotificationsDeletion PASSED

kafka.zk.KafkaZkClientTest > testGetLogConfigs STARTED

kafka.zk.KafkaZkClientTest > testGetLogConfigs PASSED

kafka.zk.KafkaZkClientTest > testBrokerSequenceIdMethods STARTED

kafka.zk.KafkaZkClientTest > testBrokerSequenceIdMethods PASSED

kafka.zk.KafkaZkClientTest > testAclMethods STARTED

kafka.zk.KafkaZkClientTest > testAclMethods PASSED

kafka.zk.KafkaZkClientTest > testCreateSequentialPersistentPath STARTED

kafka.zk.KafkaZkClientTest > testCreateSequentialPersistentPath PASSED

kafka.zk.KafkaZkClientTest > testConditionalUpdatePath STARTED

kafka.zk.KafkaZkClientTest > testConditionalUpdatePath PASSED

kafka.zk.KafkaZkClientTest > testDeleteTopicZNode STARTED

kafka.zk.KafkaZkClientTest > testDeleteTopicZNode PASSED

kafka.zk.KafkaZkClientTest > testDeletePath STARTED

kafka.zk.KafkaZkClientTest > testDeletePath PASSED

kafka.zk.KafkaZkClientTest > testGetBrokerMethods STARTED

kafka.zk.KafkaZkClientTest > testGetBrokerMethods PASSED

kafka.zk.KafkaZkClientTest > testCreateTokenChangeNotification STARTED

kafka.zk.KafkaZkClientTest > testCreateTokenChangeNotification PASSED

kafka.zk.KafkaZkClientTest > testGetTopicsAndPartitions STARTED

kafka.zk.KafkaZkClientTest > testGetTopicsAndPartitions PASSED

kafka.zk.KafkaZkClientTest > testRegisterBrokerInfo STARTED

kafka.zk.KafkaZkClientTest > testRegisterBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testRetryRegisterBrokerInfo STARTED

kafka.zk.KafkaZkClientTest > testRetryRegisterBrokerInfo PASSED

kafka.zk.KafkaZkClientTest > testConsumerOffsetPath STARTED

kafka.zk.KafkaZkClientTest > testConsumerOffsetPath PASSED

kafka.zk.KafkaZkClientTest > testDeleteRecursiveWithControllerEpochVersionCheck STARTED

kafka.zk.KafkaZkClientTest > testDeleteRecursiveWithControllerEpochVersionCheck PASSED

kafka.zk.KafkaZkClientTest > testControllerManagementMethods STARTED

kafka.zk.KafkaZkClientTest > testControllerManagementMethods PASSED

kafka.zk.KafkaZkClientTest > testTopicAssignmentMethods STARTED

kafka.zk.KafkaZkClientTest > testTopicAssignmentMethods PASSED

kafka.zk.KafkaZkClientTest > testPropagateIsrChanges STARTED

kafka.zk.KafkaZkClientTest > testPropagateIsrChanges PASSED

kafka.zk.KafkaZkClientTest > testControllerEpochMethods STARTED

kafka.zk.KafkaZkClientTest > testControllerEpochMethods PASSED

kafka.zk.KafkaZkClientTest > testDeleteRecursive STARTED

kafka.zk.KafkaZkClientTest > testDeleteRecursive PASSED

kafka.zk.KafkaZkClientTest > testGetTopicPartitionStates STARTED

kafka.zk.KafkaZkClientTest > testGetTopicPartitionStates PASSED

kafka.zk.KafkaZkClientTest > testCreateConfigChangeNotification STARTED

kafka.zk.KafkaZkClientTest > testCreateConfigChangeNotification PASSED

kafka.zk.KafkaZkClientTest > testDelegationTokenMethods STARTED

kafka.zk.KafkaZkClientTest > testDelegationTokenMethods PASSED

kafka.common.ZkNodeChangeNotificationListenerTest > testProcessNotification STARTED

kafka.common.ZkNodeChangeNotificationListenerTest > testProcessNotification PASSED

kafka.common.ZkNodeChangeNotificationListenerTest > testSwallowsProcessorException STARTED

kafka.common.ZkNodeChangeNotificationListenerTest > testSwallowsProcessorException PASSED

kafka.common.InterBrokerSendThreadTest > shouldCreateClientRequestAndSendWhenNodeIsReady STARTED

kafka.common.InterBrokerSendThreadTest > shouldCreateClientRequestAndSendWhenNodeIsReady PASSED

kafka.common.InterBrokerSendThreadTest > testFailingExpiredRequests STARTED

kafka.common.InterBrokerSendThreadTest > testFailingExpiredRequests PASSED

kafka.common.InterBrokerSendThreadTest > shouldCallCompletionHandlerWithDisconnectedResponseWhenNodeNotReady STARTED

kafka.common.InterBrokerSendThreadTest > shouldCallCompletionHandlerWithDisconnectedResponseWhenNodeNotReady PASSED

kafka.common.InterBrokerSendThreadTest > shouldNotSendAnythingWhenNoRequests STARTED

kafka.common.InterBrokerSendThreadTest > shouldNotSendAnythingWhenNoRequests PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] PASSED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate STARTED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/build/reports/tests/test/index.html>

* 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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5h 5m 18s
141 actionable tasks: 115 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=064017b2b7aff56675c10f27f2d1eb76ac221c2d, workspace=<https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #94
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user bill@confluent.io
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-2.3-jdk8 #100

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

Changes:

[bill] KAFKA-8861 Fix flaky

------------------------------------------
Started by an SCM change
Started by an SCM change
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H22 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/2.3^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/2.3^{commit} # timeout=10
Checking out Revision c7b4595f3af966426b4d46216a7ba893a3c86de1 (refs/remotes/origin/2.3)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f c7b4595f3af966426b4d46216a7ba893a3c86de1
Commit message: "KAFKA-8861 Fix flaky RegexSourceIntegrationTest.testMultipleConsumersCanReadFromPartitionedTopic (#7281)"
 > git rev-list --no-walk b9450a49ec0b7e10eca1e4413bdd6956f1a18677 # timeout=10
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[kafka-2.3-jdk8] $ /bin/bash -xe /tmp/jenkins9149281496775566872.sh
+ rm -rf <https://builds.apache.org/job/kafka-2.3-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.8.1/bin/gradle
/tmp/jenkins9149281496775566872.sh: line 4: /home/jenkins/tools/gradle/4.8.1/bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=c7b4595f3af966426b4d46216a7ba893a3c86de1, workspace=<https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #94
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user bill@confluent.io
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-2.3-jdk8 #99

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

Changes:

[rhauch] Changed for updatedTasks, avoids stopping and starting of unnecessary

[rhauch] MINOR: Add unit test for KAFKA-8676 to guard against unrequired task

------------------------------------------
[...truncated 2.92 MB...]
kafka.api.GroupAuthorizerIntegrationTest > testCommitWithTopicDescribe STARTED

kafka.api.GroupAuthorizerIntegrationTest > testCommitWithTopicDescribe PASSED

kafka.api.GroupAuthorizerIntegrationTest > testAuthorizationWithTopicExisting STARTED

kafka.api.GroupAuthorizerIntegrationTest > testAuthorizationWithTopicExisting PASSED

kafka.api.GroupAuthorizerIntegrationTest > testUnauthorizedDeleteRecordsWithoutDescribe STARTED

kafka.api.GroupAuthorizerIntegrationTest > testUnauthorizedDeleteRecordsWithoutDescribe PASSED

kafka.api.GroupAuthorizerIntegrationTest > testMetadataWithTopicDescribe STARTED

kafka.api.GroupAuthorizerIntegrationTest > testMetadataWithTopicDescribe PASSED

kafka.api.GroupAuthorizerIntegrationTest > testProduceWithTopicDescribe STARTED

kafka.api.GroupAuthorizerIntegrationTest > testProduceWithTopicDescribe PASSED

kafka.api.GroupAuthorizerIntegrationTest > testDescribeGroupApiWithNoGroupAcl STARTED

kafka.api.GroupAuthorizerIntegrationTest > testDescribeGroupApiWithNoGroupAcl PASSED

kafka.api.GroupAuthorizerIntegrationTest > testPatternSubscriptionMatchingInternalTopic STARTED

kafka.api.GroupAuthorizerIntegrationTest > testPatternSubscriptionMatchingInternalTopic PASSED

kafka.api.GroupAuthorizerIntegrationTest > testSendOffsetsWithNoConsumerGroupDescribeAccess STARTED

kafka.api.GroupAuthorizerIntegrationTest > testSendOffsetsWithNoConsumerGroupDescribeAccess PASSED

kafka.api.GroupAuthorizerIntegrationTest > testOffsetFetchTopicDescribe STARTED

kafka.api.GroupAuthorizerIntegrationTest > testOffsetFetchTopicDescribe PASSED

kafka.api.GroupAuthorizerIntegrationTest > testCommitWithTopicAndGroupRead STARTED

kafka.api.GroupAuthorizerIntegrationTest > testCommitWithTopicAndGroupRead PASSED

kafka.api.GroupAuthorizerIntegrationTest > testIdempotentProducerNoIdempotentWriteAclInInitProducerId STARTED

kafka.api.GroupAuthorizerIntegrationTest > testIdempotentProducerNoIdempotentWriteAclInInitProducerId PASSED

kafka.api.GroupAuthorizerIntegrationTest > testSimpleConsumeWithExplicitSeekAndNoGroupAccess STARTED

kafka.api.GroupAuthorizerIntegrationTest > testSimpleConsumeWithExplicitSeekAndNoGroupAccess PASSED

kafka.api.SaslPlaintextConsumerTest > testCoordinatorFailover STARTED

kafka.api.SaslPlaintextConsumerTest > testCoordinatorFailover PASSED

kafka.api.SaslPlaintextConsumerTest > testSimpleConsumption STARTED

kafka.api.SaslPlaintextConsumerTest > testSimpleConsumption PASSED

kafka.api.TransactionsTest > testBasicTransactions STARTED

kafka.api.TransactionsTest > testBasicTransactions PASSED

kafka.api.TransactionsTest > testFencingOnSendOffsets STARTED

kafka.api.TransactionsTest > testFencingOnSendOffsets PASSED

kafka.api.TransactionsTest > testFencingOnAddPartitions STARTED

kafka.api.TransactionsTest > testFencingOnAddPartitions PASSED

kafka.api.TransactionsTest > testFencingOnTransactionExpiration STARTED

kafka.api.TransactionsTest > testFencingOnTransactionExpiration PASSED

kafka.api.TransactionsTest > testDelayedFetchIncludesAbortedTransaction STARTED

kafka.api.TransactionsTest > testDelayedFetchIncludesAbortedTransaction PASSED

kafka.api.TransactionsTest > testOffsetMetadataInSendOffsetsToTransaction STARTED

kafka.api.TransactionsTest > testOffsetMetadataInSendOffsetsToTransaction PASSED

kafka.api.TransactionsTest > testConsecutivelyRunInitTransactions STARTED

kafka.api.TransactionsTest > testConsecutivelyRunInitTransactions PASSED

kafka.api.TransactionsTest > testReadCommittedConsumerShouldNotSeeUndecidedData STARTED

kafka.api.TransactionsTest > testReadCommittedConsumerShouldNotSeeUndecidedData PASSED

kafka.api.TransactionsTest > testFencingOnSend STARTED

kafka.api.TransactionsTest > testFencingOnSend PASSED

kafka.api.TransactionsTest > testFencingOnCommit STARTED

kafka.api.TransactionsTest > testFencingOnCommit PASSED

kafka.api.TransactionsTest > testMultipleMarkersOneLeader STARTED

kafka.api.TransactionsTest > testMultipleMarkersOneLeader PASSED

kafka.api.TransactionsTest > testCommitTransactionTimeout STARTED

kafka.api.TransactionsTest > testCommitTransactionTimeout PASSED

kafka.api.TransactionsTest > testSendOffsets STARTED

kafka.api.TransactionsTest > testSendOffsets PASSED

kafka.api.DescribeAuthorizedOperationsTest > testClusterAuthorizedOperations STARTED

kafka.api.DescribeAuthorizedOperationsTest > testClusterAuthorizedOperations PASSED

kafka.api.DescribeAuthorizedOperationsTest > testTopicAuthorizedOperations STARTED

kafka.api.DescribeAuthorizedOperationsTest > testTopicAuthorizedOperations PASSED

kafka.api.DescribeAuthorizedOperationsTest > testConsumerGroupAuthorizedOperations STARTED

kafka.api.DescribeAuthorizedOperationsTest > testConsumerGroupAuthorizedOperations PASSED

kafka.api.LogAppendTimeTest > testProduceConsume STARTED

kafka.api.LogAppendTimeTest > testProduceConsume PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testAcls STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testAcls PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testTwoConsumersWithDifferentSaslCredentials STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testTwoConsumersWithDifferentSaslCredentials PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaSubscribe PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeWithPrefixedAcls STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeWithPrefixedAcls PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeViaAssign STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeViaAssign PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaAssign PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeTopicAutoCreateTopicCreateAcl STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeTopicAutoCreateTopicCreateAcl PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeWithWildcardAcls STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeWithWildcardAcls PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithDescribeAclViaSubscribe PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoConsumeWithoutDescribeAclViaAssign PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoGroupAcl STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoGroupAcl PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoProduceWithDescribeAcl STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoProduceWithDescribeAcl PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoDescribeProduceOrConsumeWithoutTopicDescribeAcl STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testNoDescribeProduceOrConsumeWithoutTopicDescribeAcl PASSED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeViaSubscribe STARTED

kafka.api.SaslPlainSslEndToEndAuthorizationTest > testProduceConsumeViaSubscribe PASSED

kafka.api.ClientIdQuotaTest > testProducerConsumerOverrideUnthrottled STARTED

kafka.api.ClientIdQuotaTest > testProducerConsumerOverrideUnthrottled PASSED

kafka.api.ClientIdQuotaTest > testThrottledProducerConsumer STARTED

kafka.api.ClientIdQuotaTest > testThrottledProducerConsumer PASSED

kafka.api.ClientIdQuotaTest > testQuotaOverrideDelete STARTED

kafka.api.ClientIdQuotaTest > testQuotaOverrideDelete PASSED

kafka.api.ClientIdQuotaTest > testThrottledRequest STARTED

kafka.api.ClientIdQuotaTest > testThrottledRequest PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=true, consumerTopicCreation=false] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=true] PASSED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] STARTED

integration.kafka.api.ConsumerTopicCreationTest > testAutoTopicCreation[brokerTopicCreation=false, consumerTopicCreation=false] PASSED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate STARTED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate PASSED

FAILURE: Build failed with an exception.

* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:test'.
> There were failing tests. See the report at: file://<https://builds.apache.org/job/kafka-2.3-jdk8/ws/core/build/reports/tests/test/index.html>

* 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

Deprecated Gradle features were used in this build, making it incompatible with Gradle 6.0.
Use '--warning-mode all' to show the individual deprecation warnings.
See https://docs.gradle.org/5.4.1/userguide/command_line_interface.html#sec:command_line_warnings

BUILD FAILED in 5h 34m 36s
141 actionable tasks: 115 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=b9450a49ec0b7e10eca1e4413bdd6956f1a18677, workspace=<https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #94
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user wangguoz@gmail.com

Build failed in Jenkins: kafka-2.3-jdk8 #98

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

Changes:

[wangguoz] HOTFIX: AssignedStreamsTasksTest lacks one parameter

------------------------------------------
Started by an SCM change
[EnvInject] - Loading node environment variables.
Building remotely on H27 (ubuntu xenial) in workspace <https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[WS-CLEANUP] Deleting project workspace...
[WS-CLEANUP] Deferred wipeout is used...
No credentials specified
Cloning the remote Git repository
Cloning repository https://github.com/apache/kafka.git
 > git init <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git --version # timeout=10
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
 > git config --add remote.origin.fetch +refs/heads/*:refs/remotes/origin/* # timeout=10
 > git config remote.origin.url https://github.com/apache/kafka.git # timeout=10
Fetching upstream changes from https://github.com/apache/kafka.git
 > git fetch --tags --progress https://github.com/apache/kafka.git +refs/heads/*:refs/remotes/origin/*
 > git rev-parse refs/remotes/origin/2.3^{commit} # timeout=10
 > git rev-parse refs/remotes/origin/origin/2.3^{commit} # timeout=10
Checking out Revision 2a38ae7c492292282ed4c42845d4348e2eb166d5 (refs/remotes/origin/2.3)
 > git config core.sparsecheckout # timeout=10
 > git checkout -f 2a38ae7c492292282ed4c42845d4348e2eb166d5
Commit message: "HOTFIX: AssignedStreamsTasksTest lacks one parameter"
 > git rev-list --no-walk f1244e508d6e25c2ee603578a0c897af235fc93a # timeout=10
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[kafka-2.3-jdk8] $ /bin/bash -xe /tmp/jenkins9166934260545446155.sh
+ rm -rf <https://builds.apache.org/job/kafka-2.3-jdk8/ws/.gradle>
+ /home/jenkins/tools/gradle/4.8.1/bin/gradle
/tmp/jenkins9166934260545446155.sh: line 4: /home/jenkins/tools/gradle/4.8.1/bin/gradle: No such file or directory
Build step 'Execute shell' marked build as failure
[FINDBUGS] Collecting findbugs analysis files...
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
[FINDBUGS] Searching for all files in <https://builds.apache.org/job/kafka-2.3-jdk8/ws/> that match the pattern **/build/reports/findbugs/*.xml
[FINDBUGS] No files found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
No credentials specified
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=2a38ae7c492292282ed4c42845d4348e2eb166d5, workspace=<https://builds.apache.org/job/kafka-2.3-jdk8/ws/>
[FINDBUGS] Computing warning deltas based on reference build #94
Recording test results
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
ERROR: Step ?Publish JUnit test result report? failed: No test report files were found. Configuration error?
Setting GRADLE_4_8_1_HOME=/home/jenkins/tools/gradle/4.8.1
Not sending mail to unregistered user gwen@confluent.io
Not sending mail to unregistered user wangguoz@gmail.com