Package | Description |
---|---|
io.druid.indexer | |
io.druid.indexing.common.index | |
io.druid.indexing.common.task | |
io.druid.segment.indexing | |
io.druid.segment.realtime | |
io.druid.segment.realtime.plumber |
Modifier and Type | Method and Description |
---|---|
DataSchema |
HadoopIngestionSpec.getDataSchema() |
Modifier and Type | Method and Description |
---|---|
HadoopIngestionSpec |
HadoopIngestionSpec.withDataSchema(DataSchema schema) |
Constructor and Description |
---|
HadoopIngestionSpec(DataSchema dataSchema,
HadoopIOConfig ioConfig,
HadoopTuningConfig tuningConfig,
String dataSource,
io.druid.data.input.impl.TimestampSpec timestampSpec,
io.druid.data.input.impl.DataSpec dataSpec,
GranularitySpec granularitySpec,
Map<String,Object> pathSpec,
String workingPath,
String segmentOutputPath,
String version,
PartitionsSpec partitionsSpec,
boolean leaveIntermediate,
Boolean cleanupOnFailure,
Map<org.joda.time.DateTime,List<HadoopyShardSpec>> shardSpecs,
boolean overwriteFiles,
DataRollupSpec rollupSpec,
DbUpdaterJobSpec updaterJobSpec,
boolean ignoreInvalidRows,
Map<String,String> jobProperties,
boolean combineText,
String timestampColumn,
String timestampFormat,
List<org.joda.time.Interval> intervals,
com.metamx.common.Granularity segmentGranularity,
String partitionDimension,
Long targetPartitionSize) |
Modifier and Type | Method and Description |
---|---|
Plumber |
YeOldePlumberSchool.findPlumber(DataSchema schema,
RealtimeTuningConfig config,
FireDepartmentMetrics metrics) |
Modifier and Type | Method and Description |
---|---|
DataSchema |
IndexTask.IndexIngestionSpec.getDataSchema() |
Constructor and Description |
---|
IndexTask.IndexIngestionSpec(DataSchema dataSchema,
IndexTask.IndexIOConfig ioConfig,
IndexTask.IndexTuningConfig tuningConfig) |
Modifier and Type | Method and Description |
---|---|
DataSchema |
IngestionSpec.getDataSchema() |
DataSchema |
DataSchema.withGranularitySpec(GranularitySpec granularitySpec) |
Constructor and Description |
---|
IngestionSpec(DataSchema dataSchema,
IOConfigType ioConfig,
TuningConfigType tuningConfig) |
Modifier and Type | Method and Description |
---|---|
DataSchema |
FireDepartment.getDataSchema()
Provides the data schema for the feed that this FireDepartment is in charge of.
|
Constructor and Description |
---|
FireDepartment(DataSchema dataSchema,
RealtimeIOConfig ioConfig,
RealtimeTuningConfig tuningConfig,
Schema schema,
FireDepartmentConfig config,
io.druid.data.input.FirehoseFactory firehoseFactory,
PlumberSchool plumberSchool) |
Modifier and Type | Method and Description |
---|---|
DataSchema |
RealtimePlumber.getSchema() |
Modifier and Type | Method and Description |
---|---|
protected File |
RealtimePlumber.computeBaseDir(DataSchema schema) |
protected File |
RealtimePlumber.computePersistDir(DataSchema schema,
org.joda.time.Interval interval) |
Plumber |
RealtimePlumberSchool.findPlumber(DataSchema schema,
RealtimeTuningConfig config,
FireDepartmentMetrics metrics) |
Plumber |
PlumberSchool.findPlumber(DataSchema schema,
RealtimeTuningConfig config,
FireDepartmentMetrics metrics)
Creates a Plumber
|
Plumber |
FlushingPlumberSchool.findPlumber(DataSchema schema,
RealtimeTuningConfig config,
FireDepartmentMetrics metrics) |
protected int |
RealtimePlumber.persistHydrant(FireHydrant indexToPersist,
DataSchema schema,
org.joda.time.Interval interval)
Persists the given hydrant and returns the number of rows persisted
|
Constructor and Description |
---|
FlushingPlumber(org.joda.time.Duration flushDuration,
DataSchema schema,
RealtimeTuningConfig config,
FireDepartmentMetrics metrics,
com.metamx.emitter.service.ServiceEmitter emitter,
QueryRunnerFactoryConglomerate conglomerate,
DataSegmentAnnouncer segmentAnnouncer,
ExecutorService queryExecutorService) |
RealtimePlumber(DataSchema schema,
RealtimeTuningConfig config,
FireDepartmentMetrics metrics,
com.metamx.emitter.service.ServiceEmitter emitter,
QueryRunnerFactoryConglomerate conglomerate,
DataSegmentAnnouncer segmentAnnouncer,
ExecutorService queryExecutorService,
io.druid.segment.loading.DataSegmentPusher dataSegmentPusher,
SegmentPublisher segmentPublisher,
FilteredServerView serverView) |
Sink(org.joda.time.Interval interval,
DataSchema schema,
RealtimeTuningConfig config,
String version) |
Sink(org.joda.time.Interval interval,
DataSchema schema,
RealtimeTuningConfig config,
String version,
List<FireHydrant> hydrants) |
Copyright © 2015. All rights reserved.