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 2020/09/22 00:06:52 UTC

Build failed in Jenkins: Kafka » kafka-2.3-jdk8 #4

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

Changes:

[Jason Frantz] KAFKA-10401; Ensure `currentStateTimeStamp` is set correctly by group coordinator (#9202)


------------------------------------------
[...truncated 1.70 MB...]
kafka.zookeeper.ZooKeeperClientTest > testConnectionTimeout STARTED

kafka.zookeeper.ZooKeeperClientTest > testConnectionTimeout PASSED

kafka.zookeeper.ZooKeeperClientTest > testBlockOnRequestCompletionFromStateChangeHandler STARTED

kafka.zookeeper.ZooKeeperClientTest > testBlockOnRequestCompletionFromStateChangeHandler PASSED

kafka.zookeeper.ZooKeeperClientTest > testUnresolvableConnectString STARTED

kafka.zookeeper.ZooKeeperClientTest > testUnresolvableConnectString PASSED

kafka.zookeeper.ZooKeeperClientTest > testGetChildrenNonExistentZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testGetChildrenNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testPipelinedGetData STARTED

kafka.zookeeper.ZooKeeperClientTest > testPipelinedGetData PASSED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChildChangeHandlerForChildChange STARTED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChildChangeHandlerForChildChange PASSED

kafka.zookeeper.ZooKeeperClientTest > testGetChildrenExistingZNodeWithChildren STARTED

kafka.zookeeper.ZooKeeperClientTest > testGetChildrenExistingZNodeWithChildren PASSED

kafka.zookeeper.ZooKeeperClientTest > testSetDataExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testSetDataExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testMixedPipeline STARTED

kafka.zookeeper.ZooKeeperClientTest > testMixedPipeline PASSED

kafka.zookeeper.ZooKeeperClientTest > testGetDataExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testGetDataExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testDeleteExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testDeleteExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testSessionExpiry STARTED

kafka.zookeeper.ZooKeeperClientTest > testSessionExpiry PASSED

kafka.zookeeper.ZooKeeperClientTest > testSetDataNonExistentZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testSetDataNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testDeleteNonExistentZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testDeleteNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testExistsExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testExistsExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testZooKeeperStateChangeRateMetrics STARTED

kafka.zookeeper.ZooKeeperClientTest > testZooKeeperStateChangeRateMetrics PASSED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChangeHandlerForDeletion STARTED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChangeHandlerForDeletion PASSED

kafka.zookeeper.ZooKeeperClientTest > testGetAclNonExistentZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testGetAclNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testStateChangeHandlerForAuthFailure STARTED

kafka.zookeeper.ZooKeeperClientTest > testStateChangeHandlerForAuthFailure PASSED

kafka.metrics.KafkaTimerTest > testKafkaTimer STARTED

kafka.metrics.KafkaTimerTest > testKafkaTimer PASSED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics STARTED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testClusterIdMetric STARTED

kafka.metrics.MetricsTest > testClusterIdMetric PASSED

kafka.metrics.MetricsTest > testControllerMetrics STARTED

kafka.metrics.MetricsTest > testControllerMetrics PASSED

kafka.metrics.MetricsTest > testWindowsStyleTagNames STARTED

kafka.metrics.MetricsTest > testWindowsStyleTagNames PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut PASSED

> Task :kafka-2.3-jdk8:generator:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:generator:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:generator:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processMessages UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processResources UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:determineCommitId UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:createVersionFile
> Task :kafka-2.3-jdk8:clients:jar UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:compileTestJava UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processTestResources UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:testClasses UP-TO-DATE
> Task :kafka-2.3-jdk8:core:compileJava NO-SOURCE

> Task :kafka-2.3-jdk8:core:compileScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupMetadataManager.scala>:1154: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
          offsetAndMetadata.expireTimestamp.getOrElse(OffsetCommitRequest.DEFAULT_TIMESTAMP))
                                                                          ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupMetadataManager.scala>:1303: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
        if (expireTimestamp == OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                   ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:402: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
              case OffsetCommitRequest.DEFAULT_TIMESTAMP => currentTimestamp
                                       ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/controller/KafkaController.scala>:1561: match may not be exhaustive.
It would fail on the following input: ShutdownEventThread
      event match {
      ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupCoordinator.scala>:369: match may not be exhaustive.
It would fail on the following input: Dead
        group.currentState match {
              ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupCoordinator.scala>:522: match may not be exhaustive.
It would fail on the following input: Dead
          group.currentState match {
                ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/AdminUtils.scala>:64: trait AdminUtilities in package admin is deprecated: This class is deprecated and will be replaced by kafka.zk.AdminZkClient.
object AdminUtils extends Logging with AdminUtilities {
                                       ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/BrokerApiVersionsCommand.scala>:52: class AdminClient in package admin is deprecated: This class is deprecated in favour of org.apache.kafka.clients.admin.AdminClient and it will be removed in a future release.
  private def createAdminClient(opts: BrokerVersionCommandOptions): AdminClient = {
                                                                    ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/BrokerApiVersionsCommand.scala>:58: object AdminClient in package admin is deprecated: This class is deprecated in favour of org.apache.kafka.clients.admin.AdminClient and it will be removed in a future release.
    AdminClient.create(props)
    ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/ConfigCommand.scala>:319: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    adminClient.alterConfigs(Map(configResource -> newConfig).asJava, alterOptions).all().get(60, TimeUnit.SECONDS)
                ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:822: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
      new ListOffsetResponse.PartitionData(Errors.TOPIC_AUTHORIZATION_FAILED, List[JLong]().asJava)
      ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:830: value maxNumOffsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
          maxNumOffsets = partitionData.maxNumOffsets,
                                        ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:833: 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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:842: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:845: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:231: value DEFAULT_SASL_ENABLED_MECHANISMS in object SaslConfigs is deprecated: see corresponding Javadoc for more information.
  val SaslEnabledMechanisms = SaslConfigs.DEFAULT_SASL_ENABLED_MECHANISMS
                                          ^
<https://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:197: 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.
    private def toBaseConsumerRecord(record: ConsumerRecord[Array[Byte], Array[Byte]]): BaseConsumerRecord =
                                                                                        ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:417: 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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:421: 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]]] = {
                                ^
21 warnings found
Note: <https://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:370: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
                  .setCommitTimestamp(OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                          ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/coordinator/group/GroupMetadataManagerTest.scala>:818: overloaded method value assertThrows with alternatives:
  [T <: Throwable](x$1: String, x$2: Class[T], x$3: org.junit.function.ThrowingRunnable)T <and>
  [T <: Throwable](x$1: Class[T], x$2: org.junit.function.ThrowingRunnable)T
 cannot be applied to (Class[org.apache.kafka.common.KafkaException], () => kafka.coordinator.group.GroupMetadata)
    val e = assertThrows(classOf[KafkaException],
            ^
one warning found
one error found

> Task :kafka-2.3-jdk8:core:compileTestScala FAILED
> Task :testScala_2_11 FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':clients:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/clients/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:compileTestScala'.
> Compilation failed

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

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

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 2h 16m 15s
72 actionable tasks: 46 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results

Jenkins build is back to normal : Kafka » kafka-2.3-jdk8 #11

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


Build failed in Jenkins: Kafka » kafka-2.3-jdk8 #10

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

Changes:

[Manikumar Reddy] MINOR: Fix Scala 2.11 compile error


------------------------------------------
[...truncated 2.99 MB...]
kafka.security.auth.ZkAuthorizationTest > testIsZkSecurityEnabled PASSED

kafka.security.auth.ZkAuthorizationTest > testKafkaZkClient STARTED

kafka.security.auth.ZkAuthorizationTest > testKafkaZkClient PASSED

kafka.security.auth.ZkAuthorizationTest > testZkAntiMigration STARTED

kafka.security.auth.ZkAuthorizationTest > testZkAntiMigration PASSED

kafka.security.auth.ZkAuthorizationTest > testConsumerOffsetPathAcls STARTED

kafka.security.auth.ZkAuthorizationTest > testConsumerOffsetPathAcls PASSED

kafka.security.auth.ZkAuthorizationTest > testZkMigration STARTED

kafka.security.auth.ZkAuthorizationTest > testZkMigration PASSED

kafka.security.auth.ZkAuthorizationTest > testChroot STARTED

kafka.security.auth.ZkAuthorizationTest > testChroot PASSED

kafka.security.auth.ZkAuthorizationTest > testDelete STARTED

kafka.security.auth.ZkAuthorizationTest > testDelete PASSED

kafka.security.auth.ZkAuthorizationTest > testDeleteRecursive STARTED

kafka.security.auth.ZkAuthorizationTest > testDeleteRecursive PASSED

kafka.security.auth.OperationTest > testJavaConversions STARTED

kafka.security.auth.OperationTest > testJavaConversions PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAllAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAllAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testLocalConcurrentModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testLocalConcurrentModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyDeletionOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyDeletionOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFound STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFound PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAclInheritance STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAclInheritance PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventWhenInterBrokerProtocolAtLeastKafkaV2 STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventWhenInterBrokerProtocolAtLeastKafkaV2 PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAclManagementAPIs STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAclManagementAPIs PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWildCardAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWildCardAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralAclChangeEventWhenInterBrokerProtocolIsKafkaV2 STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralAclChangeEventWhenInterBrokerProtocolIsKafkaV2 PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testTopicAcl STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testTopicAcl PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserHasAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserHasAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDenyTakesPrecedence STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDenyTakesPrecedence PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testSingleCharacterResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testSingleCharacterResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFoundOverride STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFoundOverride PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testEmptyAclThrowsException STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testEmptyAclThrowsException PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAccessWithCustomPrincipal STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAccessWithCustomPrincipal PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testChangeListenerTiming STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testChangeListenerTiming PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithEmptyResourceName STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithEmptyResourceName PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnLiteralResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnLiteralResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeThrowsOnNoneLiteralResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeThrowsOnNoneLiteralResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testGetAclsPrincipal STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testGetAclsPrincipal PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnPrefiexedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnPrefiexedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testLoadCache STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testLoadCache PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testPeriodicTokenExpiry STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testPeriodicTokenExpiry PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testTokenRequestsWithDelegationTokenDisabled STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testTokenRequestsWithDelegationTokenDisabled PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testDescribeToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testDescribeToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testCreateToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testCreateToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testExpireToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testExpireToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testRenewToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testRenewToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testRemoveTokenHmac STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testRemoveTokenHmac PASSED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate STARTED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate 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

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://ci-builds.apache.org/job/Kafka/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 14m 37s
141 actionable tasks: 115 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results

Build failed in Jenkins: Kafka » kafka-2.3-jdk8 #9

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

Changes:

[Manikumar Reddy] Backported changes to fix tests that resolve to multiple addresses. (#9307)


------------------------------------------
[...truncated 2.57 MB...]
kafka.log.BrokerCompressionTest > testBrokerSideCompression[8] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[9] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[9] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[10] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[10] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[11] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[11] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[12] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[12] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[13] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[13] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[14] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[14] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[15] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[15] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[16] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[16] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[17] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[17] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[18] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[18] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[19] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[19] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[20] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[20] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[21] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[21] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[22] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[22] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[23] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[23] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[24] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[24] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[25] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[25] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[26] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[26] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[27] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[27] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[28] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[28] PASSED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[29] STARTED

kafka.log.BrokerCompressionTest > testBrokerSideCompression[29] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[0] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[0] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[0] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[0] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[0] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[0] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[0] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[0] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[0] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[0] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[1] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[1] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[1] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[1] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[1] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[1] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[1] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[1] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[1] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[1] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[2] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[2] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[2] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[2] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[2] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[2] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[2] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[2] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[2] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[2] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[3] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[3] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[3] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[3] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[3] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[3] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[3] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[3] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[3] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[3] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[4] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerConfigUpdateTest[4] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[4] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleansCombinedCompactAndDeleteTopic[4] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[4] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleaningNestedMessagesWithMultipleVersions[4] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[4] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > cleanerTest[4] PASSED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[4] STARTED

kafka.log.LogCleanerParameterizedIntegrationTest > testCleanerWithMessageFormatV0[4] PASSED

kafka.log.LogConfigTest > ensureNoStaticInitializationOrderDependency STARTED

kafka.log.LogConfigTest > ensureNoStaticInitializationOrderDependency PASSED

kafka.log.LogConfigTest > shouldValidateThrottledReplicasConfig STARTED

kafka.log.LogConfigTest > shouldValidateThrottledReplicasConfig PASSED

kafka.log.LogConfigTest > testFromPropsEmpty STARTED

kafka.log.LogConfigTest > testFromPropsEmpty PASSED

kafka.log.LogConfigTest > testInvalidCompactionLagConfig STARTED

kafka.log.LogConfigTest > testInvalidCompactionLagConfig PASSED

kafka.log.LogConfigTest > testKafkaConfigToProps STARTED

kafka.log.LogConfigTest > testKafkaConfigToProps PASSED

kafka.log.LogConfigTest > testFromPropsInvalid STARTED

kafka.log.LogConfigTest > testFromPropsInvalid 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:compileTestScala'.
> Compilation failed

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

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

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 2h 55m 20s
141 actionable tasks: 115 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results

Build failed in Jenkins: Kafka » kafka-2.3-jdk8 #8

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

Changes:

[Randall Hauch] KAFKA-10574: Fix infinite loop in Values::parseString (#9375)


------------------------------------------
[...truncated 1.73 MB...]

kafka.security.auth.ZkAuthorizationTest > testZkMigration STARTED

kafka.security.auth.ZkAuthorizationTest > testZkMigration PASSED

kafka.security.auth.ZkAuthorizationTest > testChroot STARTED

kafka.security.auth.ZkAuthorizationTest > testChroot PASSED

kafka.security.auth.ZkAuthorizationTest > testDelete STARTED

kafka.security.auth.ZkAuthorizationTest > testDelete PASSED

kafka.security.auth.ZkAuthorizationTest > testDeleteRecursive STARTED

kafka.security.auth.ZkAuthorizationTest > testDeleteRecursive PASSED

kafka.security.auth.OperationTest > testJavaConversions STARTED

kafka.security.auth.OperationTest > testJavaConversions PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAllAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAllAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testLocalConcurrentModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testLocalConcurrentModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyDeletionOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyDeletionOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFound STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFound PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAclInheritance STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAclInheritance PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDistributedConcurrentModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventWhenInterBrokerProtocolAtLeastKafkaV2 STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventWhenInterBrokerProtocolAtLeastKafkaV2 PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAclManagementAPIs STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAclManagementAPIs PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWildCardAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWildCardAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralAclChangeEventWhenInterBrokerProtocolIsKafkaV2 STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralAclChangeEventWhenInterBrokerProtocolIsKafkaV2 PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testTopicAcl STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testTopicAcl PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserHasAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserHasAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDenyTakesPrecedence STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDenyTakesPrecedence PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testSingleCharacterResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testSingleCharacterResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFoundOverride STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testNoAclFoundOverride PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testEmptyAclThrowsException STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testEmptyAclThrowsException PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testSuperUserWithCustomPrincipalHasAccess PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAccessWithCustomPrincipal STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAllowAccessWithCustomPrincipal PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAclOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testChangeListenerTiming STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testChangeListenerTiming PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesLiteralWritesLiteralAclChangeEventWhenInterBrokerProtocolLessThanKafkaV2eralAclChangesForOlderProtocolVersions PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testThrowsOnAddPrefixedAclIfInterBrokerProtocolVersionTooLow PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testHighConcurrencyModificationOfResourceAcls PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithEmptyResourceName STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeWithEmptyResourceName PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnPrefixedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testDeleteAllAclOnPrefixedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnLiteralResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnLiteralResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeThrowsOnNoneLiteralResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAuthorizeThrowsOnNoneLiteralResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testGetAclsPrincipal STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testGetAclsPrincipal PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnPrefiexedResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAddAclsOnPrefiexedResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testWritesExtendedAclChangeEventIfInterBrokerProtocolNotSet PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testAccessAllowedIfAllowAclExistsOnWildcardResource PASSED

kafka.security.auth.SimpleAclAuthorizerTest > testLoadCache STARTED

kafka.security.auth.SimpleAclAuthorizerTest > testLoadCache PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testPeriodicTokenExpiry STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testPeriodicTokenExpiry PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testTokenRequestsWithDelegationTokenDisabled STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testTokenRequestsWithDelegationTokenDisabled PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testDescribeToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testDescribeToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testCreateToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testCreateToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testExpireToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testExpireToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testRenewToken STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testRenewToken PASSED

kafka.security.token.delegation.DelegationTokenManagerTest > testRemoveTokenHmac STARTED

kafka.security.token.delegation.DelegationTokenManagerTest > testRemoveTokenHmac PASSED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate STARTED

unit.kafka.utils.ThrottlerTest > testThrottleDesiredRate 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

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':clients:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/clients/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:compileTestScala'.
> Compilation failed

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

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

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 2h 13m 18s
79 actionable tasks: 53 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results

Build failed in Jenkins: Kafka » kafka-2.3-jdk8 #7

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

Changes:

[Konstantine Karantasis] KAFKA-10439: Connect's Values to parse BigInteger as Decimal with zero scale. (#9320)


------------------------------------------
[...truncated 2.57 MB...]

kafka.api.AdminClientIntegrationTest > testLogStartOffsetAfterDeleteRecords STARTED

kafka.api.AdminClientIntegrationTest > testLogStartOffsetAfterDeleteRecords PASSED

kafka.api.AdminClientIntegrationTest > testValidIncrementalAlterConfigs STARTED

kafka.api.AdminClientIntegrationTest > testValidIncrementalAlterConfigs PASSED

kafka.api.AdminClientIntegrationTest > testInvalidIncrementalAlterConfigs STARTED

kafka.api.AdminClientIntegrationTest > testInvalidIncrementalAlterConfigs PASSED

kafka.api.AdminClientIntegrationTest > testSeekAfterDeleteRecords STARTED

kafka.api.AdminClientIntegrationTest > testSeekAfterDeleteRecords PASSED

kafka.api.AdminClientIntegrationTest > testCallInFlightTimeouts STARTED

kafka.api.AdminClientIntegrationTest > testCallInFlightTimeouts PASSED

kafka.api.AdminClientIntegrationTest > testDescribeConfigsForTopic STARTED

kafka.api.AdminClientIntegrationTest > testDescribeConfigsForTopic PASSED

kafka.api.AdminClientIntegrationTest > testConsumerGroups STARTED

kafka.api.AdminClientIntegrationTest > testConsumerGroups PASSED

kafka.api.AdminClientIntegrationTest > testCreateExistingTopicsThrowTopicExistsException STARTED

kafka.api.AdminClientIntegrationTest > testCreateExistingTopicsThrowTopicExistsException PASSED

kafka.metrics.KafkaTimerTest > testKafkaTimer STARTED

kafka.metrics.KafkaTimerTest > testKafkaTimer PASSED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics STARTED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testClusterIdMetric STARTED

kafka.metrics.MetricsTest > testClusterIdMetric PASSED

kafka.metrics.MetricsTest > testControllerMetrics STARTED

kafka.metrics.MetricsTest > testControllerMetrics PASSED

kafka.metrics.MetricsTest > testWindowsStyleTagNames STARTED

kafka.metrics.MetricsTest > testWindowsStyleTagNames PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut PASSED

kafka.cluster.ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark STARTED

kafka.cluster.ReplicaTest > testCannotIncrementLogStartOffsetPastHighWatermark PASSED

kafka.cluster.ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization STARTED

kafka.cluster.ReplicaTest > testSegmentDeletionWithHighWatermarkInitialization PASSED

kafka.cluster.ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark STARTED

kafka.cluster.ReplicaTest > testCannotDeleteSegmentsAtOrAboveHighWatermark PASSED

kafka.cluster.PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats STARTED

kafka.cluster.PartitionTest > testMakeLeaderDoesNotUpdateEpochCacheForOldFormats PASSED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testListOffsetIsolationLevels STARTED

kafka.cluster.PartitionTest > testListOffsetIsolationLevels PASSED

kafka.cluster.PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset STARTED

kafka.cluster.PartitionTest > testAppendRecordsAsFollowerBelowLogStartOffset PASSED

kafka.cluster.PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch STARTED

kafka.cluster.PartitionTest > testFetchLatestOffsetIncludesLeaderEpoch PASSED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testMonotonicOffsetsAfterLeaderChange STARTED

kafka.cluster.PartitionTest > testMonotonicOffsetsAfterLeaderChange PASSED

kafka.cluster.PartitionTest > testMakeFollowerWithNoLeaderIdChange STARTED

kafka.cluster.PartitionTest > testMakeFollowerWithNoLeaderIdChange PASSED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException STARTED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException PASSED

kafka.cluster.PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch STARTED

kafka.cluster.PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch PASSED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testAtMinIsr STARTED

kafka.cluster.PartitionTest > testAtMinIsr PASSED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testDelayedFetchAfterAppendRecords STARTED

kafka.cluster.PartitionTest > testDelayedFetchAfterAppendRecords PASSED

kafka.cluster.PartitionTest > testMakeLeaderUpdatesEpochCache STARTED

kafka.cluster.PartitionTest > testMakeLeaderUpdatesEpochCache PASSED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets STARTED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets PASSED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testGetReplica STARTED

kafka.cluster.PartitionTest > testGetReplica PASSED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplica STARTED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplica PASSED

kafka.cluster.BrokerEndPointTest > testEndpointFromUri STARTED

kafka.cluster.BrokerEndPointTest > testEndpointFromUri PASSED

kafka.cluster.BrokerEndPointTest > testHashAndEquals STARTED

kafka.cluster.BrokerEndPointTest > testHashAndEquals PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNoRack STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNoRack PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonFutureVersion STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonFutureVersion PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNullRack STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNullRack PASSED

kafka.cluster.BrokerEndPointTest > testBrokerEndpointFromUri STARTED

kafka.cluster.BrokerEndPointTest > testBrokerEndpointFromUri PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV1 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV1 PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV2 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV2 PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV3 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV3 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

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':clients:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/clients/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:compileTestScala'.
> Compilation failed

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

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

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 2h 59m 39s
141 actionable tasks: 115 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results

Build failed in Jenkins: Kafka » kafka-2.3-jdk8 #6

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

Changes:

[John Roesler] MINOR: remove stream simple benchmark suite (#8353)


------------------------------------------
[...truncated 1.71 MB...]
kafka.zookeeper.ZooKeeperClientTest > testGetChildrenNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testPipelinedGetData STARTED

kafka.zookeeper.ZooKeeperClientTest > testPipelinedGetData PASSED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChildChangeHandlerForChildChange STARTED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChildChangeHandlerForChildChange PASSED

kafka.zookeeper.ZooKeeperClientTest > testGetChildrenExistingZNodeWithChildren STARTED

kafka.zookeeper.ZooKeeperClientTest > testGetChildrenExistingZNodeWithChildren PASSED

kafka.zookeeper.ZooKeeperClientTest > testSetDataExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testSetDataExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testMixedPipeline STARTED

kafka.zookeeper.ZooKeeperClientTest > testMixedPipeline PASSED

kafka.zookeeper.ZooKeeperClientTest > testGetDataExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testGetDataExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testDeleteExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testDeleteExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testSessionExpiry STARTED

kafka.zookeeper.ZooKeeperClientTest > testSessionExpiry PASSED

kafka.zookeeper.ZooKeeperClientTest > testSetDataNonExistentZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testSetDataNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testDeleteNonExistentZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testDeleteNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testExistsExistingZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testExistsExistingZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testZooKeeperStateChangeRateMetrics STARTED

kafka.zookeeper.ZooKeeperClientTest > testZooKeeperStateChangeRateMetrics PASSED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChangeHandlerForDeletion STARTED

kafka.zookeeper.ZooKeeperClientTest > testZNodeChangeHandlerForDeletion PASSED

kafka.zookeeper.ZooKeeperClientTest > testGetAclNonExistentZNode STARTED

kafka.zookeeper.ZooKeeperClientTest > testGetAclNonExistentZNode PASSED

kafka.zookeeper.ZooKeeperClientTest > testStateChangeHandlerForAuthFailure STARTED

kafka.zookeeper.ZooKeeperClientTest > testStateChangeHandlerForAuthFailure PASSED

kafka.metrics.KafkaTimerTest > testKafkaTimer STARTED

kafka.metrics.KafkaTimerTest > testKafkaTimer PASSED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testMetricsReporterAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics STARTED

kafka.metrics.MetricsTest > testSessionExpireListenerMetrics PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsUnregisteredAfterDeletingTopic PASSED

kafka.metrics.MetricsTest > testClusterIdMetric STARTED

kafka.metrics.MetricsTest > testClusterIdMetric PASSED

kafka.metrics.MetricsTest > testControllerMetrics STARTED

kafka.metrics.MetricsTest > testControllerMetrics PASSED

kafka.metrics.MetricsTest > testWindowsStyleTagNames STARTED

kafka.metrics.MetricsTest > testWindowsStyleTagNames PASSED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut STARTED

kafka.metrics.MetricsTest > testBrokerTopicMetricsBytesInOut PASSED

2430 tests completed, 1 failed, 2 skipped

> Task :kafka-2.3-jdk8:core:test FAILED
> Task :testScala_2_12 FAILED
> Task :kafka-2.3-jdk8:generator:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:generator:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:generator:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processMessages UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processResources UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:determineCommitId UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:createVersionFile
> Task :kafka-2.3-jdk8:clients:jar UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:compileTestJava UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processTestResources UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:testClasses UP-TO-DATE
> Task :kafka-2.3-jdk8:core:compileJava NO-SOURCE

> Task :kafka-2.3-jdk8:core:compileScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupMetadataManager.scala>:1154: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
          offsetAndMetadata.expireTimestamp.getOrElse(OffsetCommitRequest.DEFAULT_TIMESTAMP))
                                                                          ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupMetadataManager.scala>:1303: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
        if (expireTimestamp == OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                   ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:402: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
              case OffsetCommitRequest.DEFAULT_TIMESTAMP => currentTimestamp
                                       ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/controller/KafkaController.scala>:1561: match may not be exhaustive.
It would fail on the following input: ShutdownEventThread
      event match {
      ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupCoordinator.scala>:369: match may not be exhaustive.
It would fail on the following input: Dead
        group.currentState match {
              ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupCoordinator.scala>:522: match may not be exhaustive.
It would fail on the following input: Dead
          group.currentState match {
                ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/AdminUtils.scala>:64: trait AdminUtilities in package admin is deprecated: This class is deprecated and will be replaced by kafka.zk.AdminZkClient.
object AdminUtils extends Logging with AdminUtilities {
                                       ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/BrokerApiVersionsCommand.scala>:52: class AdminClient in package admin is deprecated: This class is deprecated in favour of org.apache.kafka.clients.admin.AdminClient and it will be removed in a future release.
  private def createAdminClient(opts: BrokerVersionCommandOptions): AdminClient = {
                                                                    ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/BrokerApiVersionsCommand.scala>:58: object AdminClient in package admin is deprecated: This class is deprecated in favour of org.apache.kafka.clients.admin.AdminClient and it will be removed in a future release.
    AdminClient.create(props)
    ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/ConfigCommand.scala>:319: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    adminClient.alterConfigs(Map(configResource -> newConfig).asJava, alterOptions).all().get(60, TimeUnit.SECONDS)
                ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:822: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
      new ListOffsetResponse.PartitionData(Errors.TOPIC_AUTHORIZATION_FAILED, List[JLong]().asJava)
      ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:830: value maxNumOffsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
          maxNumOffsets = partitionData.maxNumOffsets,
                                        ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:833: 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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:842: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:845: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:231: value DEFAULT_SASL_ENABLED_MECHANISMS in object SaslConfigs is deprecated: see corresponding Javadoc for more information.
  val SaslEnabledMechanisms = SaslConfigs.DEFAULT_SASL_ENABLED_MECHANISMS
                                          ^
<https://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:197: 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.
    private def toBaseConsumerRecord(record: ConsumerRecord[Array[Byte], Array[Byte]]): BaseConsumerRecord =
                                                                                        ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:417: 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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:421: 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]]] = {
                                ^
21 warnings found
Note: <https://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:370: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
                  .setCommitTimestamp(OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                          ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/coordinator/group/GroupMetadataManagerTest.scala>:818: overloaded method value assertThrows with alternatives:
  [T <: Throwable](x$1: String, x$2: Class[T], x$3: org.junit.function.ThrowingRunnable)T <and>
  [T <: Throwable](x$1: Class[T], x$2: org.junit.function.ThrowingRunnable)T
 cannot be applied to (Class[org.apache.kafka.common.KafkaException], () => kafka.coordinator.group.GroupMetadata)
    val e = assertThrows(classOf[KafkaException],
            ^
one warning found
one error found

> Task :kafka-2.3-jdk8:core:compileTestScala FAILED
> Task :testScala_2_11 FAILED

FAILURE: Build completed with 3 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':clients:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/clients/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.
==============================================================================

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://ci-builds.apache.org/job/Kafka/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.
==============================================================================

3: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:compileTestScala'.
> Compilation failed

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

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

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 2h 7m 42s
92 actionable tasks: 66 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results

Build failed in Jenkins: Kafka » kafka-2.3-jdk8 #5

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

Changes:

[Randall Hauch] KAFKA-10477: Fix JsonConverter regression to treat MISSING nodes as NULL nodes (#9306)


------------------------------------------
[...truncated 1.70 MB...]
kafka.cluster.PartitionTest > testMakeFollowerWithNoLeaderIdChange STARTED

kafka.cluster.PartitionTest > testMakeFollowerWithNoLeaderIdChange PASSED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException STARTED

kafka.cluster.PartitionTest > testAppendRecordsToFollowerWithNoReplicaThrowsException PASSED

kafka.cluster.PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch STARTED

kafka.cluster.PartitionTest > testFollowerDoesNotJoinISRUntilCaughtUpToOffsetWithinCurrentLeaderEpoch PASSED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testFetchOffsetSnapshotEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testAtMinIsr STARTED

kafka.cluster.PartitionTest > testAtMinIsr PASSED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testOffsetForLeaderEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testDelayedFetchAfterAppendRecords STARTED

kafka.cluster.PartitionTest > testDelayedFetchAfterAppendRecords PASSED

kafka.cluster.PartitionTest > testMakeLeaderUpdatesEpochCache STARTED

kafka.cluster.PartitionTest > testMakeLeaderUpdatesEpochCache PASSED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets STARTED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplicaDifferentBaseOffsets PASSED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader STARTED

kafka.cluster.PartitionTest > testFetchOffsetForTimestampEpochValidationForLeader PASSED

kafka.cluster.PartitionTest > testGetReplica STARTED

kafka.cluster.PartitionTest > testGetReplica PASSED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForFollower STARTED

kafka.cluster.PartitionTest > testReadRecordEpochValidationForFollower PASSED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplica STARTED

kafka.cluster.PartitionTest > testMaybeReplaceCurrentWithFutureReplica PASSED

kafka.cluster.BrokerEndPointTest > testEndpointFromUri STARTED

kafka.cluster.BrokerEndPointTest > testEndpointFromUri PASSED

kafka.cluster.BrokerEndPointTest > testHashAndEquals STARTED

kafka.cluster.BrokerEndPointTest > testHashAndEquals PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNoRack STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNoRack PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonFutureVersion STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonFutureVersion PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNullRack STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV4WithNullRack PASSED

kafka.cluster.BrokerEndPointTest > testBrokerEndpointFromUri STARTED

kafka.cluster.BrokerEndPointTest > testBrokerEndpointFromUri PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV1 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV1 PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV2 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV2 PASSED

kafka.cluster.BrokerEndPointTest > testFromJsonV3 STARTED

kafka.cluster.BrokerEndPointTest > testFromJsonV3 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

> Task :kafka-2.3-jdk8:generator:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:generator:processResources NO-SOURCE
> Task :kafka-2.3-jdk8:generator:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processMessages UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:compileJava UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processResources UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:classes UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:determineCommitId UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:createVersionFile
> Task :kafka-2.3-jdk8:clients:jar UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:compileTestJava UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:processTestResources UP-TO-DATE
> Task :kafka-2.3-jdk8:clients:testClasses UP-TO-DATE
> Task :kafka-2.3-jdk8:core:compileJava NO-SOURCE

> Task :kafka-2.3-jdk8:core:compileScala
Pruning sources from previous analysis, due to incompatible CompileSetup.
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupMetadataManager.scala>:1154: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
          offsetAndMetadata.expireTimestamp.getOrElse(OffsetCommitRequest.DEFAULT_TIMESTAMP))
                                                                          ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupMetadataManager.scala>:1303: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
        if (expireTimestamp == OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                   ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:402: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
              case OffsetCommitRequest.DEFAULT_TIMESTAMP => currentTimestamp
                                       ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/controller/KafkaController.scala>:1561: match may not be exhaustive.
It would fail on the following input: ShutdownEventThread
      event match {
      ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupCoordinator.scala>:369: match may not be exhaustive.
It would fail on the following input: Dead
        group.currentState match {
              ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/coordinator/group/GroupCoordinator.scala>:522: match may not be exhaustive.
It would fail on the following input: Dead
          group.currentState match {
                ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/AdminUtils.scala>:64: trait AdminUtilities in package admin is deprecated: This class is deprecated and will be replaced by kafka.zk.AdminZkClient.
object AdminUtils extends Logging with AdminUtilities {
                                       ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/BrokerApiVersionsCommand.scala>:52: class AdminClient in package admin is deprecated: This class is deprecated in favour of org.apache.kafka.clients.admin.AdminClient and it will be removed in a future release.
  private def createAdminClient(opts: BrokerVersionCommandOptions): AdminClient = {
                                                                    ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/BrokerApiVersionsCommand.scala>:58: object AdminClient in package admin is deprecated: This class is deprecated in favour of org.apache.kafka.clients.admin.AdminClient and it will be removed in a future release.
    AdminClient.create(props)
    ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/admin/ConfigCommand.scala>:319: method alterConfigs in class AdminClient is deprecated: see corresponding Javadoc for more information.
    adminClient.alterConfigs(Map(configResource -> newConfig).asJava, alterOptions).all().get(60, TimeUnit.SECONDS)
                ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:822: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
      new ListOffsetResponse.PartitionData(Errors.TOPIC_AUTHORIZATION_FAILED, List[JLong]().asJava)
      ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:830: value maxNumOffsets in class PartitionData is deprecated: see corresponding Javadoc for more information.
          maxNumOffsets = partitionData.maxNumOffsets,
                                        ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:833: 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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:842: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaApis.scala>:845: constructor PartitionData in class PartitionData is deprecated: see corresponding Javadoc for more information.
          (topicPartition, new ListOffsetResponse.PartitionData(Errors.forException(e), List[JLong]().asJava))
                           ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/server/KafkaConfig.scala>:231: value DEFAULT_SASL_ENABLED_MECHANISMS in object SaslConfigs is deprecated: see corresponding Javadoc for more information.
  val SaslEnabledMechanisms = SaslConfigs.DEFAULT_SASL_ENABLED_MECHANISMS
                                          ^
<https://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:197: 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.
    private def toBaseConsumerRecord(record: ConsumerRecord[Array[Byte], Array[Byte]]): BaseConsumerRecord =
                                                                                        ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:417: 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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/main/scala/kafka/tools/MirrorMaker.scala>:421: 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]]] = {
                                ^
21 warnings found
Note: <https://ci-builds.apache.org/job/Kafka/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://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/test/scala/integration/kafka/api/AuthorizerIntegrationTest.scala>:370: value DEFAULT_TIMESTAMP in object OffsetCommitRequest is deprecated: see corresponding Javadoc for more information.
                  .setCommitTimestamp(OffsetCommitRequest.DEFAULT_TIMESTAMP)
                                                          ^
<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/core/src/test/scala/unit/kafka/coordinator/group/GroupMetadataManagerTest.scala>:818: overloaded method value assertThrows with alternatives:
  [T <: Throwable](x$1: String, x$2: Class[T], x$3: org.junit.function.ThrowingRunnable)T <and>
  [T <: Throwable](x$1: Class[T], x$2: org.junit.function.ThrowingRunnable)T
 cannot be applied to (Class[org.apache.kafka.common.KafkaException], () => kafka.coordinator.group.GroupMetadata)
    val e = assertThrows(classOf[KafkaException],
            ^
one warning found
one error found

> Task :kafka-2.3-jdk8:core:compileTestScala FAILED
> Task :testScala_2_11 FAILED

FAILURE: Build completed with 2 failures.

1: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':clients:test'.
> There were failing tests. See the report at: file://<https://ci-builds.apache.org/job/Kafka/job/kafka-2.3-jdk8/ws/clients/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.
==============================================================================

2: Task failed with an exception.
-----------
* What went wrong:
Execution failed for task ':kafka-2.3-jdk8:core:compileTestScala'.
> Compilation failed

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

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

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 2h 8m 2s
94 actionable tasks: 68 executed, 26 up-to-date
Build step 'Execute shell' marked build as failure
Recording test results