Package org.apache.storm.hdfs.bolt
Class HdfsBolt
java.lang.Object
org.apache.storm.topology.base.BaseComponent
org.apache.storm.topology.base.BaseRichBolt
org.apache.storm.hdfs.bolt.AbstractHdfsBolt
org.apache.storm.hdfs.bolt.HdfsBolt
- All Implemented Interfaces:
- Serializable,- IBolt,- IComponent,- IRichBolt
- See Also:
- 
Field SummaryFields inherited from class org.apache.storm.hdfs.bolt.AbstractHdfsBoltcollector, configKey, fileNameFormat, fileRetryCount, fs, fsUrl, hdfsConfig, maxOpenFiles, offset, partitioner, rotationActions, rotationCounterMap, rotationPolicy, rotationTimer, syncPolicy, tickTupleInterval, writeLock, writers
- 
Constructor SummaryConstructors
- 
Method SummaryModifier and TypeMethodDescriptionaddRotationAction(RotationAction action) voiddoPrepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) protected StringgetWriterKey(Tuple tuple) protected AbstractHDFSWritermakeNewWriter(org.apache.hadoop.fs.Path path, Tuple tuple) withConfigKey(String configKey) withFileNameFormat(FileNameFormat fileNameFormat) withMaxOpenFiles(int maxOpenFiles) withPartitioner(Partitioner partitioner) withRecordFormat(RecordFormat format) withRetryCount(int fileRetryCount) withRotationPolicy(FileRotationPolicy rotationPolicy) withSyncPolicy(SyncPolicy syncPolicy) withTickTupleIntervalSeconds(int interval) Methods inherited from class org.apache.storm.hdfs.bolt.AbstractHdfsBoltcleanup, declareOutputFields, execute, getBasePathForNextFile, getComponentConfiguration, prepare, rotateOutputFile
- 
Constructor Details- 
HdfsBoltpublic HdfsBolt()
 
- 
- 
Method Details- 
withFsUrl
- 
withConfigKey
- 
withFileNameFormat
- 
withRecordFormat
- 
withSyncPolicy
- 
withRotationPolicy
- 
addRotationAction
- 
withTickTupleIntervalSeconds
- 
withRetryCount
- 
withPartitioner
- 
withMaxOpenFiles
- 
doPreparepublic void doPrepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) throws IOException- Specified by:
- doPreparein class- AbstractHdfsBolt
- Throws:
- IOException
 
- 
getWriterKey- Specified by:
- getWriterKeyin class- AbstractHdfsBolt
 
- 
makeNewWriterprotected AbstractHDFSWriter makeNewWriter(org.apache.hadoop.fs.Path path, Tuple tuple) throws IOException - Specified by:
- makeNewWriterin class- AbstractHdfsBolt
- Throws:
- IOException
 
 
-