public class DruidRecordWriter extends Object implements org.apache.hadoop.mapred.RecordWriter<org.apache.hadoop.io.NullWritable,DruidWritable>, FileSinkOperator.RecordWriter
| Modifier and Type | Field and Description |
|---|---|
protected static org.slf4j.Logger |
LOG |
| Constructor and Description |
|---|
DruidRecordWriter(io.druid.segment.indexing.DataSchema dataSchema,
io.druid.segment.indexing.RealtimeTuningConfig realtimeTuningConfig,
io.druid.segment.loading.DataSegmentPusher dataSegmentPusher,
int maxPartitionSize,
org.apache.hadoop.fs.Path segmentsDescriptorsDir,
org.apache.hadoop.fs.FileSystem fileSystem) |
| Modifier and Type | Method and Description |
|---|---|
void |
close(boolean abort) |
void |
close(org.apache.hadoop.mapred.Reporter reporter) |
void |
write(org.apache.hadoop.io.NullWritable key,
DruidWritable value) |
void |
write(org.apache.hadoop.io.Writable w) |
public DruidRecordWriter(io.druid.segment.indexing.DataSchema dataSchema,
io.druid.segment.indexing.RealtimeTuningConfig realtimeTuningConfig,
io.druid.segment.loading.DataSegmentPusher dataSegmentPusher,
int maxPartitionSize,
org.apache.hadoop.fs.Path segmentsDescriptorsDir,
org.apache.hadoop.fs.FileSystem fileSystem)
public void write(org.apache.hadoop.io.Writable w)
throws IOException
write in interface FileSinkOperator.RecordWriterIOExceptionpublic void close(boolean abort)
throws IOException
close in interface FileSinkOperator.RecordWriterIOExceptionpublic void write(org.apache.hadoop.io.NullWritable key,
DruidWritable value)
throws IOException
write in interface org.apache.hadoop.mapred.RecordWriter<org.apache.hadoop.io.NullWritable,DruidWritable>IOExceptionpublic void close(org.apache.hadoop.mapred.Reporter reporter)
throws IOException
close in interface org.apache.hadoop.mapred.RecordWriter<org.apache.hadoop.io.NullWritable,DruidWritable>IOExceptionCopyright © 2019 The Apache Software Foundation. All Rights Reserved.