Uses of Class
org.apache.storm.task.OutputCollector
Package
Description
ElasticSearch examples classes.
-
Uses of OutputCollector in org.apache.storm
Modifier and TypeMethodDescriptionvoid
ExclamationTopology.ExclamationBolt.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.bolt
Modifier and TypeMethodDescriptionvoid
JoinBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.clojure
Modifier and TypeMethodDescriptionvoid
ClojureBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.coordination
Modifier and TypeMethodDescriptionvoid
BatchBoltExecutor.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) void
CoordinatedBolt.prepare
(Map<String, Object> config, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.daemon
Modifier and TypeMethodDescriptionvoid
Acker.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.drpc
Modifier and TypeMethodDescriptionvoid
JoinResult.prepare
(Map<String, Object> map, TopologyContext context, OutputCollector collector) void
KeyedFairBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
ReturnResults.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.elasticsearch.bolt
Modifier and TypeMethodDescriptionvoid
AbstractEsBolt.prepare
(Map<String, Object> map, TopologyContext topologyContext, OutputCollector outputCollector) void
EsIndexBolt.prepare
(Map<String, Object> map, TopologyContext topologyContext, OutputCollector outputCollector) void
EsPercolateBolt.prepare
(Map<String, Object> map, TopologyContext topologyContext, OutputCollector outputCollector) -
Uses of OutputCollector in org.apache.storm.flux.examples
Modifier and TypeMethodDescriptionvoid
StatefulWordCounter.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
TestWindowBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.hdfs.bolt
Modifier and TypeMethodDescriptionprotected abstract void
AbstractHdfsBolt.doPrepare
(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) protected void
AvroGenericRecordBolt.doPrepare
(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) void
HdfsBolt.doPrepare
(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) void
SequenceFileBolt.doPrepare
(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) final void
AbstractHdfsBolt.prepare
(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) Marked as final to prevent override.void
HdfsFileTopology.MyBolt.prepare
(Map<String, Object> config, TopologyContext context, OutputCollector collector) void
SequenceFileTopology.MyBolt.prepare
(Map<String, Object> config, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.hdfs.spout
Modifier and TypeMethodDescriptionvoid
HdfsSpoutTopology.ConstBolt.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.hive.bolt
Modifier and TypeMethodDescriptionvoid
HiveBolt.prepare
(Map<String, Object> conf, TopologyContext topologyContext, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.jdbc.bolt
Modifier and TypeMethodDescriptionvoid
AbstractJdbcBolt.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.void
JdbcInsertBolt.prepare
(Map<String, Object> map, TopologyContext topologyContext, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.jms.bolt
Modifier and TypeMethodDescriptionvoid
JmsBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Initializes JMS resources. -
Uses of OutputCollector in org.apache.storm.jms.example
Modifier and TypeMethodDescriptionvoid
GenericBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.kafka.bolt
Modifier and TypeMethodDescriptionvoid
KafkaBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.kafka.spout
Modifier and TypeMethodDescriptionvoid
KafkaSpoutTestBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.loadgen
Modifier and TypeMethodDescriptionvoid
LoadBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.metric
Modifier and TypeMethodDescriptionvoid
EventLoggerBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
MetricsConsumerBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
SystemBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.perf.bolt
Modifier and TypeMethodDescriptionvoid
DevNullBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
IdBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.perf.utils
Modifier and TypeMethodDescriptionvoid
IdentityBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.redis.bolt
Modifier and TypeMethodDescriptionvoid
AbstractRedisBolt.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.topology
Modifier and TypeMethodDescriptionvoid
LookupWordCount.PrintWordTotalCountBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
WhitelistWordCount.PrintWordTotalCountBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.sql.runtime.datasource.socket.bolt
Modifier and TypeMethodDescriptionvoid
SocketBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.st.topology.window
Modifier and TypeMethodDescriptionvoid
TimeDataVerificationBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
VerificationBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.starter
Modifier and TypeMethodDescriptionvoid
ExclamationTopology.ExclamationBolt.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) void
MultipleLoggerTopology.ExclamationLoggingBolt.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) void
MultiThreadWordCountTopology.MultiThreadedSplitSentence.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
ResourceAwareExampleTopology.ExclamationBolt.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.starter.bolt
Modifier and TypeMethodDescriptionvoid
RollingCountAggBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
RollingCountBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
SingleJoinBolt.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) void
SlidingWindowSumBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.streams.processors
ModifierConstructorDescriptionEmittingProcessorContext
(ProcessorNode processorNode, OutputCollector collector, String outputStreamId) -
Uses of OutputCollector in org.apache.storm.task
Modifier and TypeMethodDescriptionvoid
IBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Called when a task for this component is initialized within a worker on the cluster.void
ShellBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.testing
Modifier and TypeMethodDescriptionvoid
NonRichBoltTracker.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
PythonShellMetricsBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
TestAggregatesCounter.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
TestEventOrderCheckBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
TestGlobalCount.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
TestPlannerBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
TupleCaptureBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.topology
Modifier and TypeClassDescriptionprotected static class
Modifier and TypeMethodDescriptionprotected void
WindowedBoltExecutor.doPrepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector, Collection<Event<Tuple>> queue, boolean stateful) protected void
BaseStatefulBoltExecutor.init
(TopologyContext context, OutputCollector collector) void
BasicBoltExecutor.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
CheckpointTupleForwarder.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector outputCollector) void
IStatefulBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Analogue to bolt function.void
IWindowedBolt.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.void
PersistentWindowedBoltExecutor.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
StatefulBoltExecutor.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
StatefulWindowedBoltExecutor.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
WindowedBoltExecutor.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.topology.base
Modifier and TypeMethodDescriptionvoid
BaseStatefulBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) void
BaseWindowedBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.trident.topology
Modifier and TypeMethodDescriptionvoid
TridentBoltExecutor.prepare
(Map<String, Object> conf, TopologyContext context, OutputCollector collector) -
Uses of OutputCollector in org.apache.storm.utils