public class TierPartitionStateFactory extends Object
Constructor and Description |
---|
TierPartitionStateFactory(boolean tierFeatureEnabled,
boolean tierChecksumFeatureEnabled,
boolean tierCleanerFeatureEnabled,
List<String> tierCleanerExcludedTopics,
TierPartitionStateCleanupConfig tierCleanupConfig,
boolean tierPartitionStateSnapshotFeatureFlag,
int brokerId) |
TierPartitionStateFactory(boolean tierFeatureEnabled,
boolean tierChecksumFeatureEnabled,
boolean tierCleanerFeatureEnabled,
TierPartitionStateCleanupConfig tierCleanupConfig,
boolean tierPartitionStateSnapshotFeatureFlag,
int brokerId) |
Modifier and Type | Method and Description |
---|---|
TierPartitionState |
initState(File stateDir,
org.apache.kafka.common.TopicPartition topicPartition,
kafka.log.LogConfig config,
kafka.server.LogDirFailureChannel logDirFailureChannel,
kafka.utils.Scheduler scheduler,
Boolean tierChecksumState,
org.apache.kafka.common.utils.Time time) |
TierPartitionState |
initState(File stateDir,
org.apache.kafka.common.TopicPartition topicPartition,
kafka.log.LogConfig config,
kafka.server.LogDirFailureChannel logDirFailureChannel,
kafka.utils.Scheduler scheduler,
org.apache.kafka.common.utils.Time time) |
boolean |
mayEnableTiering(org.apache.kafka.common.TopicPartition topicPartition,
kafka.log.LogConfig config) |
public TierPartitionStateFactory(boolean tierFeatureEnabled, boolean tierChecksumFeatureEnabled, boolean tierCleanerFeatureEnabled, TierPartitionStateCleanupConfig tierCleanupConfig, boolean tierPartitionStateSnapshotFeatureFlag, int brokerId)
public TierPartitionStateFactory(boolean tierFeatureEnabled, boolean tierChecksumFeatureEnabled, boolean tierCleanerFeatureEnabled, List<String> tierCleanerExcludedTopics, TierPartitionStateCleanupConfig tierCleanupConfig, boolean tierPartitionStateSnapshotFeatureFlag, int brokerId)
public TierPartitionState initState(File stateDir, org.apache.kafka.common.TopicPartition topicPartition, kafka.log.LogConfig config, kafka.server.LogDirFailureChannel logDirFailureChannel, kafka.utils.Scheduler scheduler, org.apache.kafka.common.utils.Time time) throws IOException
IOException
public TierPartitionState initState(File stateDir, org.apache.kafka.common.TopicPartition topicPartition, kafka.log.LogConfig config, kafka.server.LogDirFailureChannel logDirFailureChannel, kafka.utils.Scheduler scheduler, Boolean tierChecksumState, org.apache.kafka.common.utils.Time time) throws IOException
IOException
public boolean mayEnableTiering(org.apache.kafka.common.TopicPartition topicPartition, kafka.log.LogConfig config)