Uses of Class
org.apache.storm.task.OutputCollector
Packages that use OutputCollector
Package
Description
ElasticSearch examples classes.
- 
Uses of OutputCollector in org.apache.stormMethods in org.apache.storm with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidExclamationTopology.ExclamationBolt.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.boltMethods in org.apache.storm.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidJoinBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.clojureMethods in org.apache.storm.clojure with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidClojureBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.coordinationMethods in org.apache.storm.coordination with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidBatchBoltExecutor.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) voidCoordinatedBolt.prepare(Map<String, Object> config, TopologyContext context, OutputCollector collector) Constructors in org.apache.storm.coordination with parameters of type OutputCollector
- 
Uses of OutputCollector in org.apache.storm.daemonMethods in org.apache.storm.daemon with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidAcker.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.drpcMethods in org.apache.storm.drpc with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidJoinResult.prepare(Map<String, Object> map, TopologyContext context, OutputCollector collector) voidKeyedFairBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidReturnResults.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.elasticsearch.boltFields in org.apache.storm.elasticsearch.bolt declared as OutputCollectorMethods in org.apache.storm.elasticsearch.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidAbstractEsBolt.prepare(Map<String, Object> map, TopologyContext topologyContext, OutputCollector outputCollector) voidEsIndexBolt.prepare(Map<String, Object> map, TopologyContext topologyContext, OutputCollector outputCollector) voidEsPercolateBolt.prepare(Map<String, Object> map, TopologyContext topologyContext, OutputCollector outputCollector) 
- 
Uses of OutputCollector in org.apache.storm.flux.examplesMethods in org.apache.storm.flux.examples with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidStatefulWordCounter.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidTestWindowBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.hdfs.boltFields in org.apache.storm.hdfs.bolt declared as OutputCollectorMethods in org.apache.storm.hdfs.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionprotected abstract voidAbstractHdfsBolt.doPrepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) protected voidAvroGenericRecordBolt.doPrepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) voidHdfsBolt.doPrepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) voidSequenceFileBolt.doPrepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) final voidAbstractHdfsBolt.prepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) Marked as final to prevent override.voidHdfsFileTopology.MyBolt.prepare(Map<String, Object> config, TopologyContext context, OutputCollector collector) voidSequenceFileTopology.MyBolt.prepare(Map<String, Object> config, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.hdfs.spoutMethods in org.apache.storm.hdfs.spout with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidHdfsSpoutTopology.ConstBolt.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.hive.boltMethods in org.apache.storm.hive.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidHiveBolt.prepare(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.jdbc.boltFields in org.apache.storm.jdbc.bolt declared as OutputCollectorMethods in org.apache.storm.jdbc.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidAbstractJdbcBolt.prepare(Map<String, Object> map, TopologyContext topologyContext, OutputCollector outputCollector) Subclasses should call this to ensure output collector and connection provider are set up, and finally jdbcClient is initialized properly.voidJdbcInsertBolt.prepare(Map<String, Object> map, TopologyContext topologyContext, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.jms.boltMethods in org.apache.storm.jms.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidJmsBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Initializes JMS resources.
- 
Uses of OutputCollector in org.apache.storm.jms.exampleMethods in org.apache.storm.jms.example with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidGenericBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.kafka.boltMethods in org.apache.storm.kafka.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidKafkaBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.kafka.spoutMethods in org.apache.storm.kafka.spout with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidKafkaSpoutTestBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.loadgenMethods in org.apache.storm.loadgen with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidLoadBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.metricMethods in org.apache.storm.metric with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidEventLoggerBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidMetricsConsumerBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidSystemBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.perf.boltMethods in org.apache.storm.perf.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidDevNullBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidIdBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.perf.utilsMethods in org.apache.storm.perf.utils with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidIdentityBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.redis.boltFields in org.apache.storm.redis.bolt declared as OutputCollectorMethods in org.apache.storm.redis.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidAbstractRedisBolt.prepare(Map<String, Object> map, TopologyContext topologyContext, OutputCollector collector) Called when a task for this component is initialized within a worker on the cluster.
- 
Uses of OutputCollector in org.apache.storm.redis.topologyMethods in org.apache.storm.redis.topology with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidLookupWordCount.PrintWordTotalCountBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidWhitelistWordCount.PrintWordTotalCountBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.sql.runtime.datasource.socket.boltMethods in org.apache.storm.sql.runtime.datasource.socket.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidSocketBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.st.topology.windowMethods in org.apache.storm.st.topology.window with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidTimeDataVerificationBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidVerificationBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.starterMethods in org.apache.storm.starter with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidExclamationTopology.ExclamationBolt.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) voidMultipleLoggerTopology.ExclamationLoggingBolt.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) voidMultiThreadWordCountTopology.MultiThreadedSplitSentence.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidResourceAwareExampleTopology.ExclamationBolt.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.starter.boltMethods in org.apache.storm.starter.bolt with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidRollingCountAggBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidRollingCountBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidSingleJoinBolt.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) voidSlidingWindowSumBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.streams.processorsConstructors in org.apache.storm.streams.processors with parameters of type OutputCollectorModifierConstructorDescriptionEmittingProcessorContext(ProcessorNode processorNode, OutputCollector collector, String outputStreamId) 
- 
Uses of OutputCollector in org.apache.storm.taskMethods in org.apache.storm.task with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidIBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Called when a task for this component is initialized within a worker on the cluster.voidShellBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.testingMethods in org.apache.storm.testing with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidNonRichBoltTracker.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidPythonShellMetricsBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidTestAggregatesCounter.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidTestEventOrderCheckBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidTestGlobalCount.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidTestPlannerBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidTupleCaptureBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.topologySubclasses of OutputCollector in org.apache.storm.topologyModifier and TypeClassDescriptionprotected static classFields in org.apache.storm.topology declared as OutputCollectorMethods in org.apache.storm.topology with parameters of type OutputCollectorModifier and TypeMethodDescriptionprotected voidWindowedBoltExecutor.doPrepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector, Collection<Event<Tuple>> queue, boolean stateful) protected voidBaseStatefulBoltExecutor.init(TopologyContext context, OutputCollector collector) voidBasicBoltExecutor.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidCheckpointTupleForwarder.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector outputCollector) voidIStatefulBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Analogue to bolt function.voidIWindowedBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) This is similar to theIBolt.prepare(Map, TopologyContext, OutputCollector)except that while emitting, the tuples are automatically anchored to the tuples in the inputWindow.voidPersistentWindowedBoltExecutor.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidStatefulBoltExecutor.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidStatefulWindowedBoltExecutor.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidWindowedBoltExecutor.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Constructors in org.apache.storm.topology with parameters of type OutputCollector
- 
Uses of OutputCollector in org.apache.storm.topology.baseMethods in org.apache.storm.topology.base with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidBaseStatefulBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) voidBaseWindowedBolt.prepare(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.trident.topologyMethods in org.apache.storm.trident.topology with parameters of type OutputCollectorModifier and TypeMethodDescriptionvoidTridentBoltExecutor.prepare(Map<String, Object> conf, TopologyContext context, OutputCollector collector) 
- 
Uses of OutputCollector in org.apache.storm.utilsConstructors in org.apache.storm.utils with parameters of type OutputCollector