Package org.apache.storm.trident.planner
Interface TridentProcessor
- 
- All Superinterfaces:
- Serializable,- TupleReceiver
 - All Known Implementing Classes:
- AggregateProcessor,- EachProcessor,- MapProcessor,- MultiReducerProcessor,- PartitionPersistProcessor,- ProjectedProcessor,- StateQueryProcessor,- WindowTridentProcessor
 
 public interface TridentProcessor extends Serializable, TupleReceiver 
- 
- 
Method SummaryAll Methods Instance Methods Abstract Methods Modifier and Type Method Description voidcleanup()voidfinishBatch(ProcessorContext processorContext)TridentTuple.FactorygetOutputFactory()voidprepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)voidstartBatch(ProcessorContext processorContext)- 
Methods inherited from interface org.apache.storm.trident.planner.TupleReceiverexecute, flush
 
- 
 
- 
- 
- 
Method Detail- 
preparevoid prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext) 
 - 
cleanupvoid cleanup() 
 - 
startBatchvoid startBatch(ProcessorContext processorContext) 
 - 
finishBatchvoid finishBatch(ProcessorContext processorContext) 
 - 
getOutputFactoryTridentTuple.Factory getOutputFactory() 
 
- 
 
-