public class MetadataShellObserver extends Object implements org.apache.kafka.metadata.util.ClusterMetadataSource
Constructor and Description |
---|
MetadataShellObserver(String quorumVoters,
String clusterId,
kafka.raft.KafkaRaftManager<org.apache.kafka.server.common.ApiMessageAndVersion> raftManager,
Path tempDir) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
caughtUpFuture() |
void |
close() |
void |
start(org.apache.kafka.raft.RaftClient.Listener<org.apache.kafka.server.common.ApiMessageAndVersion> listener) |
String |
toString() |
public void start(org.apache.kafka.raft.RaftClient.Listener<org.apache.kafka.server.common.ApiMessageAndVersion> listener) throws Exception
start
in interface org.apache.kafka.metadata.util.ClusterMetadataSource
Exception
public CompletableFuture<Void> caughtUpFuture()
caughtUpFuture
in interface org.apache.kafka.metadata.util.ClusterMetadataSource
public void close() throws Exception
close
in interface AutoCloseable
close
in interface org.apache.kafka.metadata.util.ClusterMetadataSource
Exception