public class HdfsBolt extends AbstractHdfsBolt
collector, configKey, fileNameFormat, fileRetryCount, fs, fsUrl, hdfsConfig, maxOpenFiles, offset, partitioner, rotationActions, rotationCounterMap, rotationPolicy, rotationTimer, syncPolicy, tickTupleInterval, writeLock, writers
Constructor and Description |
---|
HdfsBolt() |
Modifier and Type | Method and Description |
---|---|
HdfsBolt |
addRotationAction(RotationAction action) |
void |
doPrepare(Map<String,Object> conf,
TopologyContext topologyContext,
OutputCollector collector) |
protected String |
getWriterKey(Tuple tuple) |
protected AbstractHDFSWriter |
makeNewWriter(org.apache.hadoop.fs.Path path,
Tuple tuple) |
HdfsBolt |
withConfigKey(String configKey) |
HdfsBolt |
withFileNameFormat(FileNameFormat fileNameFormat) |
HdfsBolt |
withFsUrl(String fsUrl) |
HdfsBolt |
withMaxOpenFiles(int maxOpenFiles) |
HdfsBolt |
withPartitioner(Partitioner partitioner) |
HdfsBolt |
withRecordFormat(RecordFormat format) |
HdfsBolt |
withRetryCount(int fileRetryCount) |
HdfsBolt |
withRotationPolicy(FileRotationPolicy rotationPolicy) |
HdfsBolt |
withSyncPolicy(SyncPolicy syncPolicy) |
HdfsBolt |
withTickTupleIntervalSeconds(int interval) |
cleanup, declareOutputFields, execute, getBasePathForNextFile, getComponentConfiguration, prepare, rotateOutputFile
public HdfsBolt withFileNameFormat(FileNameFormat fileNameFormat)
public HdfsBolt withRecordFormat(RecordFormat format)
public HdfsBolt withSyncPolicy(SyncPolicy syncPolicy)
public HdfsBolt withRotationPolicy(FileRotationPolicy rotationPolicy)
public HdfsBolt addRotationAction(RotationAction action)
public HdfsBolt withTickTupleIntervalSeconds(int interval)
public HdfsBolt withRetryCount(int fileRetryCount)
public HdfsBolt withPartitioner(Partitioner partitioner)
public HdfsBolt withMaxOpenFiles(int maxOpenFiles)
public void doPrepare(Map<String,Object> conf, TopologyContext topologyContext, OutputCollector collector) throws IOException
doPrepare
in class AbstractHdfsBolt
IOException
protected String getWriterKey(Tuple tuple)
getWriterKey
in class AbstractHdfsBolt
protected AbstractHDFSWriter makeNewWriter(org.apache.hadoop.fs.Path path, Tuple tuple) throws IOException
makeNewWriter
in class AbstractHdfsBolt
IOException
Copyright © 2022 The Apache Software Foundation. All rights reserved.