public class TierTopicMaterializationUtils extends Object
Modifier and Type | Field and Description |
---|---|
org.apache.kafka.clients.consumer.KafkaConsumer<byte[],byte[]> |
consumer |
Constructor and Description |
---|
TierTopicMaterializationUtils(TierTopicMaterializationToolConfig config,
Properties additionalConsumerProps,
Map<TopicIdPartition,Long> offsetMap,
org.apache.kafka.server.util.Scheduler scheduler) |
TierTopicMaterializationUtils(TierTopicMaterializationToolConfig config,
Properties additionalConsumerProps,
org.apache.kafka.server.util.Scheduler scheduler) |
Modifier and Type | Method and Description |
---|---|
long |
getStartOffset(org.apache.kafka.common.TopicPartition tp)
getStartOffset will return the beginning offset of a given TopicPartition 'tp'.
|
Path |
getTierStateFile(TopicIdPartition id) |
void |
run() |
void |
setupConsumer(TierTopicMaterializationToolConfig config) |
public org.apache.kafka.clients.consumer.KafkaConsumer<byte[],byte[]> consumer
public TierTopicMaterializationUtils(TierTopicMaterializationToolConfig config, Properties additionalConsumerProps, Map<TopicIdPartition,Long> offsetMap, org.apache.kafka.server.util.Scheduler scheduler)
public TierTopicMaterializationUtils(TierTopicMaterializationToolConfig config, Properties additionalConsumerProps, org.apache.kafka.server.util.Scheduler scheduler)
public void setupConsumer(TierTopicMaterializationToolConfig config)
public void run() throws IOException
IOException
public Path getTierStateFile(TopicIdPartition id)
public long getStartOffset(org.apache.kafka.common.TopicPartition tp)
tp
- is TopicPartition