Uses of Class
org.apache.storm.task.OutputCollector
-
-
Uses of OutputCollector in org.apache.storm
Methods in org.apache.storm with parameters of type OutputCollector Modifier and Type Method Description void
ExclamationTopology.ExclamationBolt. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.bolt
Methods in org.apache.storm.bolt with parameters of type OutputCollector Modifier and Type Method Description void
JoinBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.clojure
Methods in org.apache.storm.clojure with parameters of type OutputCollector Modifier and Type Method Description void
ClojureBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.coordination
Methods in org.apache.storm.coordination with parameters of type OutputCollector Modifier and Type Method Description void
BatchBoltExecutor. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
void
CoordinatedBolt. prepare(Map<String,Object> config, TopologyContext context, OutputCollector collector)
Constructors in org.apache.storm.coordination with parameters of type OutputCollector Constructor Description BatchOutputCollectorImpl(OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.daemon
Methods in org.apache.storm.daemon with parameters of type OutputCollector Modifier and Type Method Description void
Acker. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.drpc
Methods in org.apache.storm.drpc with parameters of type OutputCollector Modifier and Type Method Description void
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.flux.examples
Methods in org.apache.storm.flux.examples with parameters of type OutputCollector Modifier and Type Method Description void
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
Fields in org.apache.storm.hdfs.bolt declared as OutputCollector Modifier and Type Field Description protected OutputCollector
AbstractHdfsBolt. collector
Methods in org.apache.storm.hdfs.bolt with parameters of type OutputCollector Modifier and Type Method Description protected 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)
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
Methods in org.apache.storm.hdfs.spout with parameters of type OutputCollector Modifier and Type Method Description void
HdfsSpoutTopology.ConstBolt. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.hive.bolt
Methods in org.apache.storm.hive.bolt with parameters of type OutputCollector Modifier and Type Method Description void
HiveBolt. prepare(Map<String,Object> conf, TopologyContext topologyContext, OutputCollector collector)
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of OutputCollector in org.apache.storm.jdbc.bolt
Fields in org.apache.storm.jdbc.bolt declared as OutputCollector Modifier and Type Field Description protected OutputCollector
AbstractJdbcBolt. collector
Methods in org.apache.storm.jdbc.bolt with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.jms.bolt with parameters of type OutputCollector Modifier and Type Method Description void
JmsBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
Initializes JMS resources. -
Uses of OutputCollector in org.apache.storm.jms.example
Methods in org.apache.storm.jms.example with parameters of type OutputCollector Modifier and Type Method Description void
GenericBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.kafka.bolt
Methods in org.apache.storm.kafka.bolt with parameters of type OutputCollector Modifier and Type Method Description void
KafkaBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.kafka.spout
Methods in org.apache.storm.kafka.spout with parameters of type OutputCollector Modifier and Type Method Description void
KafkaSpoutTestBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.loadgen
Methods in org.apache.storm.loadgen with parameters of type OutputCollector Modifier and Type Method Description void
LoadBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.metric
Methods in org.apache.storm.metric with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.perf.bolt with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.perf.utils with parameters of type OutputCollector Modifier and Type Method Description void
IdentityBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.redis.bolt
Fields in org.apache.storm.redis.bolt declared as OutputCollector Modifier and Type Field Description protected OutputCollector
AbstractRedisBolt. collector
Methods in org.apache.storm.redis.bolt with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.redis.topology with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.sql.runtime.datasource.socket.bolt with parameters of type OutputCollector Modifier and Type Method Description void
SocketBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.st.topology.window
Methods in org.apache.storm.st.topology.window with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.starter with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.starter.bolt with parameters of type OutputCollector Modifier and Type Method Description void
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
Constructors in org.apache.storm.streams.processors with parameters of type OutputCollector Constructor Description EmittingProcessorContext(ProcessorNode processorNode, OutputCollector collector, String outputStreamId)
-
Uses of OutputCollector in org.apache.storm.task
Methods in org.apache.storm.task with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.testing with parameters of type OutputCollector Modifier and Type Method Description void
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
Subclasses of OutputCollector in org.apache.storm.topology Modifier and Type Class Description protected static class
BaseStatefulBoltExecutor.AnchoringOutputCollector
Fields in org.apache.storm.topology declared as OutputCollector Modifier and Type Field Description protected OutputCollector
BaseStatefulBoltExecutor. collector
Methods in org.apache.storm.topology with parameters of type OutputCollector Modifier and Type Method Description protected 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)
Constructors in org.apache.storm.topology with parameters of type OutputCollector Constructor Description BasicOutputCollector(OutputCollector out)
-
Uses of OutputCollector in org.apache.storm.topology.base
Methods in org.apache.storm.topology.base with parameters of type OutputCollector Modifier and Type Method Description void
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
Methods in org.apache.storm.trident.topology with parameters of type OutputCollector Modifier and Type Method Description void
TridentBoltExecutor. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
-
Uses of OutputCollector in org.apache.storm.utils
Constructors in org.apache.storm.utils with parameters of type OutputCollector Constructor Description BatchHelper(int batchSize, OutputCollector collector)
-