Skip to content

Commit

Permalink
fix compilation failure
Browse files Browse the repository at this point in the history
  • Loading branch information
showuon committed May 8, 2023
1 parent c817956 commit 92ebf0d
Show file tree
Hide file tree
Showing 3 changed files with 4 additions and 5 deletions.
1 change: 0 additions & 1 deletion core/src/main/scala/kafka/raft/RaftManager.scala
Expand Up @@ -47,7 +47,6 @@ import org.apache.kafka.common.utils.{LogContext, Time}
import org.apache.kafka.raft.RaftConfig.{AddressSpec, InetAddressSpec, NON_ROUTABLE_ADDRESS, UnknownAddressSpec}
import org.apache.kafka.raft.{FileBasedStateStore, KafkaRaftClient, LeaderAndEpoch, RaftClient, RaftConfig, RaftRequest, ReplicatedLog}
import org.apache.kafka.server.common.serialization.RecordSerde
import org.apache.kafka.server.util.KafkaScheduler
import org.apache.kafka.server.fault.FaultHandler

import scala.jdk.CollectionConverters._
Expand Down
4 changes: 2 additions & 2 deletions core/src/main/scala/kafka/server/KafkaServer.scala
Expand Up @@ -53,7 +53,7 @@ import org.apache.kafka.raft.RaftConfig
import org.apache.kafka.server.authorizer.Authorizer
import org.apache.kafka.server.common.{ApiMessageAndVersion, MetadataVersion}
import org.apache.kafka.server.common.MetadataVersion._
import org.apache.kafka.server.fault.ProcessExitingFaultHandler
import org.apache.kafka.server.fault.ProcessTerminatingFaultHandler
import org.apache.kafka.server.metrics.KafkaYammerMetrics
import org.apache.zookeeper.client.ZKClientConfig

Expand Down Expand Up @@ -388,7 +388,7 @@ class KafkaServer(
metrics,
threadNamePrefix,
controllerQuorumVotersFuture,
fatalFaultHandler = new ProcessExitingFaultHandler()
fatalFaultHandler = new ProcessTerminatingFaultHandler.Builder().build()
)
val controllerNodes = RaftConfig.voterConnectionsToNodes(controllerQuorumVotersFuture.get()).asScala
val quorumControllerNodeProvider = RaftControllerNodeProvider(raftManager, config, controllerNodes)
Expand Down
4 changes: 2 additions & 2 deletions core/src/main/scala/kafka/tools/TestRaftServer.scala
Expand Up @@ -38,7 +38,7 @@ import org.apache.kafka.common.{TopicPartition, Uuid, protocol}
import org.apache.kafka.raft.errors.NotLeaderException
import org.apache.kafka.raft.{Batch, BatchReader, LeaderAndEpoch, RaftClient, RaftConfig}
import org.apache.kafka.server.common.serialization.RecordSerde
import org.apache.kafka.server.fault.ProcessExitingFaultHandler
import org.apache.kafka.server.fault.ProcessTerminatingFaultHandler
import org.apache.kafka.snapshot.SnapshotReader

import scala.jdk.CollectionConverters._
Expand Down Expand Up @@ -91,7 +91,7 @@ class TestRaftServer(
metrics,
Some(threadNamePrefix),
CompletableFuture.completedFuture(RaftConfig.parseVoterConnections(config.quorumVoters)),
new ProcessExitingFaultHandler()
new ProcessTerminatingFaultHandler.Builder().build()
)

workloadGenerator = new RaftWorkloadGenerator(
Expand Down

0 comments on commit 92ebf0d

Please sign in to comment.