public class KafkaTuningConfig extends Object implements io.druid.segment.realtime.appenderator.AppenderatorConfig
| Constructor and Description |
|---|
KafkaTuningConfig(Integer maxRowsInMemory,
Integer maxRowsPerSegment,
org.joda.time.Period intermediatePersistPeriod,
File basePersistDirectory,
Integer maxPendingPersists,
io.druid.segment.IndexSpec indexSpec,
Boolean buildV9Directly,
Boolean reportParseExceptions,
Long handoffConditionTimeout,
Boolean resetOffsetAutomatically) |
| Modifier and Type | Method and Description |
|---|---|
static KafkaTuningConfig |
copyOf(KafkaTuningConfig config) |
boolean |
equals(Object o) |
File |
getBasePersistDirectory() |
boolean |
getBuildV9Directly()
Deprecated.
|
long |
getHandoffConditionTimeout()
Deprecated.
|
io.druid.segment.IndexSpec |
getIndexSpec() |
org.joda.time.Period |
getIntermediatePersistPeriod() |
int |
getMaxPendingPersists() |
int |
getMaxRowsInMemory() |
int |
getMaxRowsPerSegment() |
io.druid.segment.writeout.SegmentWriteOutMediumFactory |
getSegmentWriteOutMediumFactory() |
int |
hashCode() |
boolean |
isReportParseExceptions() |
boolean |
isResetOffsetAutomatically() |
String |
toString() |
KafkaTuningConfig |
withBasePersistDirectory(File dir) |
public KafkaTuningConfig(Integer maxRowsInMemory, Integer maxRowsPerSegment, org.joda.time.Period intermediatePersistPeriod, File basePersistDirectory, Integer maxPendingPersists, io.druid.segment.IndexSpec indexSpec, Boolean buildV9Directly, Boolean reportParseExceptions, Long handoffConditionTimeout, Boolean resetOffsetAutomatically)
public static KafkaTuningConfig copyOf(KafkaTuningConfig config)
public int getMaxRowsInMemory()
getMaxRowsInMemory in interface io.druid.segment.realtime.appenderator.AppenderatorConfigpublic int getMaxRowsPerSegment()
public org.joda.time.Period getIntermediatePersistPeriod()
getIntermediatePersistPeriod in interface io.druid.segment.realtime.appenderator.AppenderatorConfigpublic File getBasePersistDirectory()
getBasePersistDirectory in interface io.druid.segment.realtime.appenderator.AppenderatorConfig@Nullable public io.druid.segment.writeout.SegmentWriteOutMediumFactory getSegmentWriteOutMediumFactory()
getSegmentWriteOutMediumFactory in interface io.druid.segment.realtime.appenderator.AppenderatorConfigpublic int getMaxPendingPersists()
getMaxPendingPersists in interface io.druid.segment.realtime.appenderator.AppenderatorConfigpublic io.druid.segment.IndexSpec getIndexSpec()
getIndexSpec in interface io.druid.segment.realtime.appenderator.AppenderatorConfig@Deprecated public boolean getBuildV9Directly()
public boolean isReportParseExceptions()
isReportParseExceptions in interface io.druid.segment.realtime.appenderator.AppenderatorConfig@Deprecated public long getHandoffConditionTimeout()
public boolean isResetOffsetAutomatically()
public KafkaTuningConfig withBasePersistDirectory(File dir)
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.