| Modifier and Type | Method and Description | 
|---|---|
void | 
ExclamationTopology.ExclamationBolt.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
JoinBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
protected void | 
BaseExecutionResultHandler.onDriverException(com.datastax.driver.core.exceptions.DriverException e,
                 OutputCollector collector,
                 Tuple tuple)
This method is called when an one of the methods of the  
BaseExecutionResultHandler is not overridden. | 
void | 
ExecutionResultHandler.onQuerySuccess(OutputCollector collector,
              Tuple tuple)
Invoked when a query is executed with success. 
 | 
void | 
BaseExecutionResultHandler.onQuerySuccess(OutputCollector collector,
              Tuple tuple)
Invoked when a query is executed with success. 
 | 
void | 
ExecutionResultHandler.onQueryValidationException(com.datastax.driver.core.exceptions.QueryValidationException e,
                          OutputCollector collector,
                          Tuple tuple)
Invoked when a  
QueryValidationException is thrown. | 
void | 
BaseExecutionResultHandler.onQueryValidationException(com.datastax.driver.core.exceptions.QueryValidationException e,
                          OutputCollector collector,
                          Tuple tuple)
Invoked when a  
QueryValidationException is thrown. | 
void | 
ExecutionResultHandler.onReadTimeoutException(com.datastax.driver.core.exceptions.ReadTimeoutException e,
                      OutputCollector collector,
                      Tuple tuple)
Invoked when a  
ReadTimeoutException is thrown. | 
void | 
BaseExecutionResultHandler.onReadTimeoutException(com.datastax.driver.core.exceptions.ReadTimeoutException e,
                      OutputCollector collector,
                      Tuple tuple)
Invoked when a  
ReadTimeoutException is thrown. | 
void | 
ExecutionResultHandler.onThrowable(Throwable t,
           OutputCollector collector,
           List<Tuple> tl)
Default method used to handle any type of exception. 
 | 
void | 
AbstractExecutionResultHandler.onThrowable(Throwable t,
           OutputCollector collector,
           List<Tuple> tl)  | 
void | 
ExecutionResultHandler.onThrowable(Throwable t,
           OutputCollector collector,
           Tuple i)
Default method used to handle any type of exception. 
 | 
void | 
AbstractExecutionResultHandler.onThrowable(Throwable t,
           OutputCollector collector,
           Tuple i)  | 
void | 
ExecutionResultHandler.onUnavailableException(com.datastax.driver.core.exceptions.UnavailableException e,
                      OutputCollector collector,
                      Tuple tuple)
Invoked when a  
UnavailableException is thrown. | 
void | 
BaseExecutionResultHandler.onUnavailableException(com.datastax.driver.core.exceptions.UnavailableException e,
                      OutputCollector collector,
                      Tuple tuple)
Invoked when a  
UnavailableException is thrown. | 
void | 
ExecutionResultHandler.onWriteTimeoutException(com.datastax.driver.core.exceptions.WriteTimeoutException e,
                       OutputCollector collector,
                       Tuple tuple)
Invoked when a  
WriteTimeoutException is thrown. | 
void | 
BaseExecutionResultHandler.onWriteTimeoutException(com.datastax.driver.core.exceptions.WriteTimeoutException e,
                       OutputCollector collector,
                       Tuple tuple)
Invoked when a  
WriteTimeoutException is thrown. | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
BaseCassandraBolt.outputCollector  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
BatchCassandraWriterBolt.prepare(Map<String,Object> topoConfig,
       TopologyContext topologyContext,
       OutputCollector outputCollector)
Called when a task for this component is initialized within a worker on the cluster. 
 | 
void | 
BaseCassandraBolt.prepare(Map<String,Object> topoConfig,
       TopologyContext topologyContext,
       OutputCollector outputCollector)
Called when a task for this component is initialized within a worker on the cluster. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
AsyncResultHandler.flush(OutputCollector collector)  | 
void | 
ExecutionResultCollector.handle(OutputCollector collector,
      ExecutionResultHandler handler)  | 
void | 
ExecutionResultCollector.SucceedCollector.handle(OutputCollector collector,
      ExecutionResultHandler handler)
Calls  
ExecutionResultHandler.onQuerySuccess(org.apache.storm.task.OutputCollector, org.apache.storm.tuple.Tuple) before acknowledging an single input tuple. | 
void | 
ExecutionResultCollector.FailedCollector.handle(OutputCollector collector,
      ExecutionResultHandler handler)
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SingleAsyncResultHandler.flush(OutputCollector collector) | 
void | 
BatchAsyncResultHandler.flush(OutputCollector collector) | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ClojureBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
CoordinatedBolt.prepare(Map<String,Object> config,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
BatchBoltExecutor.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
| Constructor and Description | 
|---|
BatchOutputCollectorImpl(OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Acker.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ReturnResults.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
KeyedFairBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
JoinResult.prepare(Map<String,Object> map,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
AbstractEsBolt.collector  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
EsPercolateBolt.prepare(Map<String,Object> map,
       TopologyContext topologyContext,
       OutputCollector outputCollector)  | 
void | 
EsIndexBolt.prepare(Map<String,Object> map,
       TopologyContext topologyContext,
       OutputCollector outputCollector)  | 
void | 
AbstractEsBolt.prepare(Map<String,Object> map,
       TopologyContext topologyContext,
       OutputCollector outputCollector)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
EventHubBolt.collector  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
EventHubBolt.prepare(Map<String,Object> config,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TestWindowBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
StatefulWordCounter.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
AbstractHBaseBolt.collector  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
HBaseLookupBolt.prepare(Map<String,Object> config,
       TopologyContext topologyContext,
       OutputCollector collector)  | 
void | 
HBaseBolt.prepare(Map<String,Object> map,
       TopologyContext topologyContext,
       OutputCollector collector)  | 
void | 
AbstractHBaseBolt.prepare(Map<String,Object> topoConf,
       TopologyContext topologyContext,
       OutputCollector collector)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
AbstractHdfsBolt.collector  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SequenceFileBolt.doPrepare(Map<String,Object> conf,
         TopologyContext topologyContext,
         OutputCollector collector)  | 
void | 
HdfsBolt.doPrepare(Map<String,Object> conf,
         TopologyContext topologyContext,
         OutputCollector collector)  | 
protected void | 
AvroGenericRecordBolt.doPrepare(Map<String,Object> conf,
         TopologyContext topologyContext,
         OutputCollector collector)  | 
protected abstract void | 
AbstractHdfsBolt.doPrepare(Map<String,Object> conf,
         TopologyContext topologyContext,
         OutputCollector collector)  | 
void | 
SequenceFileTopology.MyBolt.prepare(Map<String,Object> config,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
HdfsFileTopology.MyBolt.prepare(Map<String,Object> config,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
AbstractHdfsBolt.prepare(Map<String,Object> conf,
       TopologyContext topologyContext,
       OutputCollector collector)
Marked as final to prevent override. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
HdfsSpoutTopology.ConstBolt.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
HiveBolt.prepare(Map<String,Object> conf,
       TopologyContext topologyContext,
       OutputCollector collector)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
AbstractJdbcBolt.collector  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
JdbcInsertBolt.prepare(Map<String,Object> map,
       TopologyContext topologyContext,
       OutputCollector collector)  | 
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. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
JmsBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)
Initializes JMS resources. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
GenericBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
KafkaBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
KafkaSpoutTestBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
LoadBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SystemBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
MetricsConsumerBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
EventLoggerBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
AbstractMongoBolt.collector  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
MongoInsertBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
AbstractMongoBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
MqttBolt.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
OpenTsdbBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IdBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
DevNullBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IdentityBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
PMMLPredictorBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
AbstractRedisBolt.collector  | 
| Modifier and Type | Method and 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. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
WhitelistWordCount.PrintWordTotalCountBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
LookupWordCount.PrintWordTotalCountBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
RocketMqBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SolrUpdateBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SocketBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
VerificationBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
TimeDataVerificationBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ResourceAwareExampleTopology.ExclamationBolt.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
MultipleLoggerTopology.ExclamationLoggingBolt.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
ExclamationTopology.ExclamationBolt.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SlidingWindowSumBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
SingleJoinBolt.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
RollingCountBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
RollingCountAggBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Constructor and Description | 
|---|
EmittingProcessorContext(ProcessorNode processorNode,
                        OutputCollector collector,
                        String outputStreamId)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ShellBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
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. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TupleCaptureBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
TestPlannerBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
TestGlobalCount.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
TestEventOrderCheckBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
TestAggregatesCounter.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
PythonShellMetricsBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
NonRichBoltTracker.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Class and Description | 
|---|---|
protected static class  | 
BaseStatefulBoltExecutor.AnchoringOutputCollector  | 
| Modifier and Type | Field and Description | 
|---|---|
protected OutputCollector | 
BaseStatefulBoltExecutor.collector  | 
| Modifier and Type | Method and 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 | 
WindowedBoltExecutor.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
StatefulWindowedBoltExecutor.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
StatefulBoltExecutor.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
PersistentWindowedBoltExecutor.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
IWindowedBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)
This is similar to the  
IBolt.prepare(Map, TopologyContext, OutputCollector) except that while emitting, the tuples are automatically anchored to the tuples in the inputWindow. | 
void | 
IStatefulBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
CheckpointTupleForwarder.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector outputCollector)  | 
void | 
BasicBoltExecutor.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Constructor and Description | 
|---|
BasicOutputCollector(OutputCollector out)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
BaseWindowedBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
void | 
BaseStatefulBolt.prepare(Map<String,Object> topoConf,
       TopologyContext context,
       OutputCollector collector)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TridentBoltExecutor.prepare(Map<String,Object> conf,
       TopologyContext context,
       OutputCollector collector)  | 
| Constructor and Description | 
|---|
BatchHelper(int batchSize,
           OutputCollector collector)  | 
Copyright © 2019 The Apache Software Foundation. All rights reserved.