Skip to content

Commit

Permalink
KAFKA-18423: Remove ZkData and related unused references (#18605)
Browse files Browse the repository at this point in the history
Also removed:

* ZkNodeChangeNotificationListener
* KafkaZkClient

Reviewers: Ismael Juma <[email protected]>
  • Loading branch information
FrankYang0529 authored Jan 19, 2025
1 parent 029d918 commit 85ec8b5
Show file tree
Hide file tree
Showing 7 changed files with 5 additions and 389 deletions.
297 changes: 0 additions & 297 deletions core/src/main/scala/kafka/zk/KafkaZkClient.scala

This file was deleted.

63 changes: 0 additions & 63 deletions core/src/main/scala/kafka/zk/ZkData.scala

This file was deleted.

Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,6 @@ import kafka.log.{LogManager, UnifiedLog}
import kafka.server.QuotaFactory.QuotaManagers
import kafka.server.{KafkaConfig, _}
import kafka.utils._
import kafka.zk.KafkaZkClient
import org.apache.kafka.common.TopicPartition
import org.apache.kafka.common.protocol.Errors
import org.apache.kafka.common.record.{MemoryRecords, RecordBatch, RecordValidationStats}
Expand All @@ -50,7 +49,6 @@ abstract class AbstractCoordinatorConcurrencyTest[M <: CoordinatorMember] extend
val serverProps = TestUtils.createBrokerConfig(0)
val random = new Random
var replicaManager: TestReplicaManager = _
var zkClient: KafkaZkClient = _
var time: MockTime = _
var timer: MockTimer = _
var executor: ExecutorService = _
Expand All @@ -67,7 +65,6 @@ abstract class AbstractCoordinatorConcurrencyTest[M <: CoordinatorMember] extend
val producePurgatory = new DelayedOperationPurgatory[DelayedProduce]("Produce", timer, 1, 1000, false, true)
val watchKeys = Collections.newSetFromMap(new ConcurrentHashMap[TopicPartitionOperationKey, java.lang.Boolean]()).asScala
replicaManager = TestReplicaManager(KafkaConfig.fromProps(serverProps), time, scheduler, timer, mockLogMger, mock(classOf[QuotaManagers], withSettings().stubOnly()), producePurgatory, watchKeys)
zkClient = mock(classOf[KafkaZkClient], withSettings().stubOnly())
}

@AfterEach
Expand Down
Loading

0 comments on commit 85ec8b5

Please sign in to comment.