Modifier and Type | Method and Description |
---|---|
IndexSpec |
HadoopTuningConfig.getIndexSpec() |
IndexSpec |
HadoopDruidIndexerConfig.getIndexSpec() |
Constructor and Description |
---|
HadoopTuningConfig(String workingPath,
String version,
PartitionsSpec partitionsSpec,
Map<Long,List<HadoopyShardSpec>> shardSpecs,
IndexSpec indexSpec,
Integer maxRowsInMemory,
boolean leaveIntermediate,
Boolean cleanupOnFailure,
boolean overwriteFiles,
boolean ignoreInvalidRows,
Map<String,String> jobProperties,
boolean combineText,
Boolean useCombiner,
Integer maxRowsInMemoryCOMPAT,
Boolean buildV9Directly,
Integer numBackgroundPersistThreads,
boolean forceExtendableShardSpecs,
boolean useExplicitVersion) |
Modifier and Type | Method and Description |
---|---|
IndexSpec |
HadoopDruidConverterConfig.getIndexSpec() |
Constructor and Description |
---|
HadoopDruidConverterConfig(String dataSource,
org.joda.time.Interval interval,
IndexSpec indexSpec,
List<DataSegment> segments,
Boolean validate,
URI distributedSuccessCache,
Map<String,String> hadoopProperties,
String jobPriority,
String segmentOutputPath) |
Modifier and Type | Method and Description |
---|---|
IndexSpec |
IndexTask.IndexTuningConfig.getIndexSpec() |
IndexSpec |
ConvertSegmentTask.getIndexSpec() |
Modifier and Type | Method and Description |
---|---|
static ConvertSegmentTask |
ConvertSegmentTask.create(DataSegment segment,
IndexSpec indexSpec,
boolean force,
boolean validate,
Map<String,Object> context)
Create a task to update the segment specified to the most recent binary version with the specified indexSpec
|
static ConvertSegmentTask |
ConvertSegmentTask.create(String dataSource,
org.joda.time.Interval interval,
IndexSpec indexSpec,
boolean force,
boolean validate,
Map<String,Object> context)
Create a segment converter task to convert a segment to the most recent version including the specified indexSpec
|
protected Iterable<Task> |
HadoopConverterTask.generateSubTasks(String groupId,
Iterable<DataSegment> segments,
IndexSpec indexSpec,
boolean force,
boolean validate,
Map<String,Object> context) |
protected Iterable<Task> |
ConvertSegmentTask.generateSubTasks(String groupId,
Iterable<DataSegment> segments,
IndexSpec indexSpec,
boolean force,
boolean validate,
Map<String,Object> context) |
Constructor and Description |
---|
AppendTask(String id,
String dataSource,
List<DataSegment> segments,
List<AggregatorFactory> aggregators,
IndexSpec indexSpec,
Boolean buildV9Directly,
Map<String,Object> context) |
ConvertSegmentBackwardsCompatibleTask(String id,
String dataSource,
org.joda.time.Interval interval,
DataSegment segment,
IndexSpec indexSpec,
Boolean force,
Boolean validate)
Deprecated.
|
ConvertSegmentTask(String id,
String dataSource,
org.joda.time.Interval interval,
DataSegment segment,
IndexSpec indexSpec,
boolean force,
boolean validate,
Map<String,Object> context) |
HadoopConverterTask(String id,
String dataSource,
org.joda.time.Interval interval,
IndexSpec indexSpec,
boolean force,
Boolean validate,
List<String> hadoopDependencyCoordinates,
URI distributedSuccessCache,
String jobPriority,
String segmentOutputPath,
String classpathPrefix,
Map<String,Object> context) |
IndexTuningConfig(Integer targetPartitionSize,
Integer maxRowsInMemory,
Integer rowFlushBoundary_forBackCompatibility,
Integer numShards,
IndexSpec indexSpec,
Integer maxPendingPersists,
Boolean buildV9Directly,
Boolean forceExtendableShardSpecs,
Boolean reportParseExceptions) |
MergeTask(String id,
String dataSource,
List<DataSegment> segments,
List<AggregatorFactory> aggregators,
Boolean rollup,
IndexSpec indexSpec,
Boolean buildV9Directly,
Map<String,Object> context) |
SubTask(String groupId,
DataSegment segment,
IndexSpec indexSpec,
Boolean force,
Boolean validate)
Deprecated.
|
SubTask(String groupId,
DataSegment segment,
IndexSpec indexSpec,
Boolean force,
Boolean validate,
Map<String,Object> context) |
Modifier and Type | Method and Description |
---|---|
IndexSpec |
KafkaTuningConfig.getIndexSpec() |
Constructor and Description |
---|
KafkaTuningConfig(Integer maxRowsInMemory,
Integer maxRowsPerSegment,
org.joda.time.Period intermediatePersistPeriod,
File basePersistDirectory,
Integer maxPendingPersists,
IndexSpec indexSpec,
Boolean buildV9Directly,
Boolean reportParseExceptions,
Long handoffConditionTimeout,
Boolean resetOffsetAutomatically) |
Constructor and Description |
---|
KafkaSupervisorTuningConfig(Integer maxRowsInMemory,
Integer maxRowsPerSegment,
org.joda.time.Period intermediatePersistPeriod,
File basePersistDirectory,
Integer maxPendingPersists,
IndexSpec indexSpec,
Boolean buildV9Directly,
Boolean reportParseExceptions,
Long handoffConditionTimeout,
Boolean resetOffsetAutomatically,
Integer workerThreads,
Integer chatThreads,
Long chatRetries,
org.joda.time.Period httpTimeout,
org.joda.time.Period shutdownTimeout) |
Modifier and Type | Field and Description |
---|---|
protected IndexSpec |
StringDimensionMergerV9.indexSpec |
protected IndexSpec |
LongDimensionMergerV9.indexSpec |
protected IndexSpec |
FloatDimensionMergerV9.indexSpec |
Modifier and Type | Method and Description |
---|---|
File |
IndexMerger.append(List<IndexableAdapter> indexes,
AggregatorFactory[] aggregators,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.append(List<IndexableAdapter> indexes,
AggregatorFactory[] aggregators,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
File |
IndexMerger.convert(File inDir,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.convert(File inDir,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
boolean |
IndexIO.convertSegment(File toConvert,
File converted,
IndexSpec indexSpec) |
boolean |
IndexIO.convertSegment(File toConvert,
File converted,
IndexSpec indexSpec,
boolean forceIfCurrent,
boolean validate) |
void |
IndexIO.DefaultIndexIOHandler.convertV8toV9(File v8Dir,
File v9Dir,
IndexSpec indexSpec) |
protected File |
IndexMergerV9.makeIndexFiles(List<IndexableAdapter> adapters,
AggregatorFactory[] metricAggs,
File outDir,
ProgressIndicator progress,
List<String> mergedDimensions,
List<String> mergedMetrics,
com.google.common.base.Function<ArrayList<Iterable<Rowboat>>,Iterable<Rowboat>> rowMergerFn,
IndexSpec indexSpec) |
protected File |
IndexMerger.makeIndexFiles(List<IndexableAdapter> indexes,
AggregatorFactory[] metricAggs,
File outDir,
ProgressIndicator progress,
List<String> mergedDimensions,
List<String> mergedMetrics,
com.google.common.base.Function<ArrayList<Iterable<Rowboat>>,Iterable<Rowboat>> rowMergerFn,
IndexSpec indexSpec) |
DimensionMergerLegacy |
StringDimensionHandler.makeLegacyMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress) |
DimensionMergerLegacy<Long> |
LongDimensionHandler.makeLegacyMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress) |
DimensionMergerLegacy<Float> |
FloatDimensionHandler.makeLegacyMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress) |
DimensionMergerLegacy<EncodedKeyComponentType> |
DimensionHandler.makeLegacyMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress)
Creates a new DimensionMergerLegacy, a per-dimension object responsible for merging indexes/row data across
segments and building the on-disk representation of a dimension.
|
DimensionMergerV9 |
StringDimensionHandler.makeMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress) |
DimensionMergerV9<Long> |
LongDimensionHandler.makeMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress) |
DimensionMergerV9<Float> |
FloatDimensionHandler.makeMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress) |
DimensionMergerV9<EncodedKeyComponentType> |
DimensionHandler.makeMerger(IndexSpec indexSpec,
File outDir,
IOPeon ioPeon,
ColumnCapabilities capabilities,
ProgressIndicator progress)
Creates a new DimensionMergerV9, a per-dimension object responsible for merging indexes/row data across segments
and building the on-disk representation of a dimension.
|
File |
IndexMerger.merge(List<IndexableAdapter> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.merge(List<IndexableAdapter> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
File |
IndexMerger.mergeQueryableIndex(List<QueryableIndex> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.mergeQueryableIndex(List<QueryableIndex> indexes,
boolean rollup,
AggregatorFactory[] metricAggs,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
File |
IndexMerger.persist(IncrementalIndex index,
File outDir,
IndexSpec indexSpec) |
File |
IndexMerger.persist(IncrementalIndex index,
org.joda.time.Interval dataInterval,
File outDir,
IndexSpec indexSpec)
This is *not* thread-safe and havok will ensue if this is called and writes are still occurring
on the IncrementalIndex object.
|
File |
IndexMerger.persist(IncrementalIndex index,
org.joda.time.Interval dataInterval,
File outDir,
IndexSpec indexSpec,
ProgressIndicator progress) |
Modifier and Type | Method and Description |
---|---|
IndexSpec |
RealtimeTuningConfig.getIndexSpec() |
Constructor and Description |
---|
RealtimeTuningConfig(Integer maxRowsInMemory,
org.joda.time.Period intermediatePersistPeriod,
org.joda.time.Period windowPeriod,
File basePersistDirectory,
VersioningPolicy versioningPolicy,
RejectionPolicyFactory rejectionPolicyFactory,
Integer maxPendingPersists,
ShardSpec shardSpec,
IndexSpec indexSpec,
Boolean buildV9Directly,
int persistThreadPriority,
int mergeThreadPriority,
Boolean reportParseExceptions,
Long handoffConditionTimeout) |
Modifier and Type | Method and Description |
---|---|
IndexSpec |
AppenderatorConfig.getIndexSpec() |
Copyright © 2011–2017. All rights reserved.