Uses of Class
org.apache.storm.task.TopologyContext
-
-
Uses of TopologyContext in org.apache.storm
Methods in org.apache.storm with parameters of type TopologyContext Modifier and Type Method Description void
ExclamationTopology.FixedOrderWordSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
ExclamationTopology.ExclamationBolt. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.bolt
Methods in org.apache.storm.bolt with parameters of type TopologyContext Modifier and Type Method Description void
JoinBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.clojure
Methods in org.apache.storm.clojure with parameters of type TopologyContext Modifier and Type Method Description void
ClojureSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
ClojureBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.coordination
Methods in org.apache.storm.coordination with parameters of type TopologyContext 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)
void
IBatchBolt. prepare(Map<String,Object> conf, TopologyContext context, BatchOutputCollector collector, T id)
-
Uses of TopologyContext in org.apache.storm.daemon
Methods in org.apache.storm.daemon that return TopologyContext Modifier and Type Method Description TopologyContext
Task. getUserContext()
Methods in org.apache.storm.daemon with parameters of type TopologyContext Modifier and Type Method Description void
Acker. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.daemon.metrics
Methods in org.apache.storm.daemon.metrics with parameters of type TopologyContext Modifier and Type Method Description static void
BuiltinMetricsUtil. registerIconnectionServerMetric(Object server, Map<String,Object> topoConf, TopologyContext context)
static void
BuiltinMetricsUtil. registerMetric(String name, IMetric metric, Map<String,Object> topoConf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.drpc
Methods in org.apache.storm.drpc with parameters of type TopologyContext Modifier and Type Method Description void
DRPCSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
JoinResult. prepare(Map<String,Object> map, TopologyContext context, OutputCollector collector)
void
KeyedFairBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
PrepareRequest. prepare(Map<String,Object> map, TopologyContext context)
void
ReturnResults. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.flux.examples
Methods in org.apache.storm.flux.examples with parameters of type TopologyContext 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)
void
WordCounter. prepare(Map<String,Object> topoConf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.hdfs.bolt
Methods in org.apache.storm.hdfs.bolt with parameters of type TopologyContext 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
HdfsFileTopology.SentenceSpout. open(Map<String,Object> config, TopologyContext context, SpoutOutputCollector collector)
void
SequenceFileTopology.SentenceSpout. open(Map<String,Object> config, TopologyContext context, SpoutOutputCollector 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 TopologyContext in org.apache.storm.hdfs.bolt.format
Methods in org.apache.storm.hdfs.bolt.format with parameters of type TopologyContext Modifier and Type Method Description void
DefaultFileNameFormat. prepare(Map<String,Object> conf, TopologyContext topologyContext)
void
FileNameFormat. prepare(Map<String,Object> conf, TopologyContext topologyContext)
void
SimpleFileNameFormat. prepare(Map<String,Object> conf, TopologyContext topologyContext)
-
Uses of TopologyContext in org.apache.storm.hdfs.spout
Methods in org.apache.storm.hdfs.spout with parameters of type TopologyContext Modifier and Type Method Description void
HdfsSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
HdfsSpoutTopology.ConstBolt. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.hdfs.trident
Methods in org.apache.storm.hdfs.trident with parameters of type TopologyContext Modifier and Type Method Description void
FixedBatchSpout. open(Map<String,Object> conf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.hive.bolt
Methods in org.apache.storm.hive.bolt with parameters of type TopologyContext Modifier and Type Method Description void
BucketTestHiveTopology.UserDataSpout. open(Map<String,Object> config, TopologyContext context, SpoutOutputCollector collector)
void
HiveTopology.UserDataSpout. open(Map<String,Object> config, TopologyContext context, SpoutOutputCollector collector)
void
HiveTopologyPartitioned.UserDataSpout. open(Map<String,Object> config, TopologyContext context, SpoutOutputCollector collector)
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 TopologyContext in org.apache.storm.hive.trident
Methods in org.apache.storm.hive.trident with parameters of type TopologyContext Modifier and Type Method Description void
TridentHiveTopology.FixedBatchSpout. open(Map<String,Object> conf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.hooks
Methods in org.apache.storm.hooks with parameters of type TopologyContext Modifier and Type Method Description void
BaseTaskHook. prepare(Map<String,Object> conf, TopologyContext context)
void
ITaskHook. prepare(Map<String,Object> conf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.hooks.info
Methods in org.apache.storm.hooks.info with parameters of type TopologyContext Modifier and Type Method Description void
BoltAckInfo. applyOn(TopologyContext topologyContext)
void
BoltExecuteInfo. applyOn(TopologyContext topologyContext)
void
BoltFailInfo. applyOn(TopologyContext topologyContext)
void
EmitInfo. applyOn(TopologyContext topologyContext)
void
SpoutAckInfo. applyOn(TopologyContext topologyContext)
void
SpoutFailInfo. applyOn(TopologyContext topologyContext)
-
Uses of TopologyContext in org.apache.storm.jdbc.bolt
Methods in org.apache.storm.jdbc.bolt with parameters of type TopologyContext 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 TopologyContext in org.apache.storm.jdbc.spout
Methods in org.apache.storm.jdbc.spout with parameters of type TopologyContext Modifier and Type Method Description void
UserSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.jms.bolt
Methods in org.apache.storm.jms.bolt with parameters of type TopologyContext Modifier and Type Method Description void
JmsBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
Initializes JMS resources. -
Uses of TopologyContext in org.apache.storm.jms.example
Methods in org.apache.storm.jms.example with parameters of type TopologyContext Modifier and Type Method Description void
GenericBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.jms.spout
Methods in org.apache.storm.jms.spout with parameters of type TopologyContext Modifier and Type Method Description void
JmsSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector spoutOutputCollector)
ISpout
implementation. -
Uses of TopologyContext in org.apache.storm.jms.trident
Methods in org.apache.storm.jms.trident with parameters of type TopologyContext Modifier and Type Method Description ITridentSpout.BatchCoordinator<JmsBatch>
TridentJmsSpout. getCoordinator(String txStateId, Map<String,Object> conf, TopologyContext context)
ITridentSpout.Emitter<JmsBatch>
TridentJmsSpout. getEmitter(String txStateId, Map<String,Object> conf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.kafka.bolt
Methods in org.apache.storm.kafka.bolt with parameters of type TopologyContext Modifier and Type Method Description void
KafkaBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
PreparableCallback. prepare(Map<String,Object> topoConf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.kafka.spout
Methods in org.apache.storm.kafka.spout with parameters of type TopologyContext Modifier and Type Method Description void
EmptyKafkaTupleListener. open(Map<String,Object> conf, TopologyContext context)
void
KafkaSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
KafkaTupleListener. open(Map<String,Object> conf, TopologyContext context)
Called during the initialization of the kafka spout.void
KafkaSpoutTestBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.kafka.spout.internal
Constructors in org.apache.storm.kafka.spout.internal with parameters of type TopologyContext Constructor Description CommitMetadataManager(TopologyContext context, KafkaSpoutConfig.ProcessingGuarantee processingGuarantee)
Create a manager with the given context. -
Uses of TopologyContext in org.apache.storm.kafka.spout.metrics2
Constructors in org.apache.storm.kafka.spout.metrics2 with parameters of type TopologyContext Constructor Description KafkaOffsetMetricManager(Supplier<Map<org.apache.kafka.common.TopicPartition,OffsetManager>> offsetManagerSupplier, Supplier<org.apache.kafka.clients.admin.Admin> adminSupplier, TopologyContext topologyContext)
-
Uses of TopologyContext in org.apache.storm.kafka.spout.subscription
Methods in org.apache.storm.kafka.spout.subscription with parameters of type TopologyContext Modifier and Type Method Description Set<org.apache.kafka.common.TopicPartition>
ManualPartitioner. getPartitionsForThisTask(List<org.apache.kafka.common.TopicPartition> allPartitionsSorted, TopologyContext context)
Filter the list of all partitions handled by this set of spouts to get only the partitions assigned to this task.Set<org.apache.kafka.common.TopicPartition>
RoundRobinManualPartitioner. getPartitionsForThisTask(List<org.apache.kafka.common.TopicPartition> allPartitionsSorted, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.kafka.spout.trident
Methods in org.apache.storm.kafka.spout.trident with parameters of type TopologyContext Modifier and Type Method Description IOpaquePartitionedTridentSpout.Coordinator<List<Map<String,Object>>>
KafkaTridentSpoutOpaque. getCoordinator(Map<String,Object> conf, TopologyContext context)
IPartitionedTridentSpout.Coordinator<List<Map<String,Object>>>
KafkaTridentSpoutTransactional. getCoordinator(Map<String,Object> conf, TopologyContext context)
IOpaquePartitionedTridentSpout.Emitter<List<Map<String,Object>>,KafkaTridentSpoutTopicPartition,Map<String,Object>>
KafkaTridentSpoutOpaque. getEmitter(Map<String,Object> conf, TopologyContext context)
IPartitionedTridentSpout.Emitter<List<Map<String,Object>>,KafkaTridentSpoutTopicPartition,Map<String,Object>>
KafkaTridentSpoutTransactional. getEmitter(Map<String,Object> conf, TopologyContext context)
Constructors in org.apache.storm.kafka.spout.trident with parameters of type TopologyContext Constructor Description KafkaTridentSpoutEmitter(KafkaTridentSpoutConfig<K,V> kafkaSpoutConfig, TopologyContext topologyContext)
Create a new Kafka spout emitter. -
Uses of TopologyContext in org.apache.storm.lambda
Methods in org.apache.storm.lambda with parameters of type TopologyContext Modifier and Type Method Description void
LambdaSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.loadgen
Methods in org.apache.storm.loadgen with parameters of type TopologyContext Modifier and Type Method Description void
LoadSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
HttpForwardingMetricsConsumer. prepare(Map<String,Object> topoConf, Object registrationArgument, TopologyContext context, IErrorReporter errorReporter)
void
LoadBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
ThroughputVsLatency.SplitSentence. prepare(Map<String,Object> stormConf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.metric
Methods in org.apache.storm.metric with parameters of type TopologyContext Modifier and Type Method Description void
EventLoggerBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
FileBasedEventLogger. prepare(Map<String,Object> conf, Map<String,Object> arguments, TopologyContext context)
void
IEventLogger. prepare(Map<String,Object> conf, Map<String,Object> arguments, TopologyContext context)
void
LoggingMetricsConsumer. prepare(Map<String,Object> topoConf, Object registrationArgument, TopologyContext context, IErrorReporter errorReporter)
void
MetricsConsumerBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
SystemBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.metric.api
Methods in org.apache.storm.metric.api with parameters of type TopologyContext Modifier and Type Method Description void
IMetricsConsumer. prepare(Map<String,Object> topoConf, Object registrationArgument, TopologyContext context, IErrorReporter errorReporter)
void
IMetricsRegistrant. registerMetrics(TopologyContext topoContext, Map<String,Object> topoConf)
-
Uses of TopologyContext in org.apache.storm.metrics2
Methods in org.apache.storm.metrics2 with parameters of type TopologyContext Modifier and Type Method Description com.codahale.metrics.Counter
StormMetricRegistry. counter(String name, TopologyContext context)
<T> com.codahale.metrics.Gauge<T>
StormMetricRegistry. gauge(String name, com.codahale.metrics.Gauge<T> gauge, TopologyContext context)
com.codahale.metrics.Histogram
StormMetricRegistry. histogram(String name, TopologyContext context)
com.codahale.metrics.Meter
StormMetricRegistry. meter(String name, TopologyContext context)
void
StormMetricRegistry. metricSet(String prefix, com.codahale.metrics.MetricSet set, TopologyContext context)
void
WorkerMetricRegistrant. registerMetrics(TopologyContext topologyContext)
com.codahale.metrics.Timer
StormMetricRegistry. timer(String name, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.metrics2.cgroup
Methods in org.apache.storm.metrics2.cgroup with parameters of type TopologyContext Modifier and Type Method Description void
CGroupCpu. registerMetrics(TopologyContext topologyContext)
void
CGroupCpuGuarantee. registerMetrics(TopologyContext topologyContext)
void
CGroupCpuGuaranteeByCfsQuota. registerMetrics(TopologyContext topologyContext)
void
CGroupCpuStat. registerMetrics(TopologyContext topologyContext)
void
CGroupMemoryLimit. registerMetrics(TopologyContext topologyContext)
void
CGroupMemoryUsage. registerMetrics(TopologyContext topologyContext)
-
Uses of TopologyContext in org.apache.storm.multilang
Methods in org.apache.storm.multilang with parameters of type TopologyContext Modifier and Type Method Description Number
ISerializer. connect(Map<String,Object> conf, TopologyContext context)
This method transmits the Storm config to the non-JVM process and receives its pid.Number
JsonSerializer. connect(Map<String,Object> conf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.perf.bolt
Methods in org.apache.storm.perf.bolt with parameters of type TopologyContext Modifier and Type Method Description void
CountBolt. prepare(Map<String,Object> topoConf, TopologyContext context)
void
DevNullBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
IdBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
SplitSentenceBolt. prepare(Map<String,Object> topoConf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.perf.spout
Methods in org.apache.storm.perf.spout with parameters of type TopologyContext Modifier and Type Method Description void
ConstSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
FileReadSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
StringGenSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
WordGenSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.perf.utils
Methods in org.apache.storm.perf.utils with parameters of type TopologyContext Modifier and Type Method Description void
IdentityBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.redis.bolt
Methods in org.apache.storm.redis.bolt with parameters of type TopologyContext 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 TopologyContext in org.apache.storm.redis.state
Methods in org.apache.storm.redis.state with parameters of type TopologyContext Modifier and Type Method Description State
RedisKeyValueStateProvider. newState(String namespace, Map<String,Object> topoConf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.redis.topology
Methods in org.apache.storm.redis.topology with parameters of type TopologyContext Modifier and Type Method Description void
WordSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
LookupWordCount.PrintWordTotalCountBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
WhitelistWordCount.PrintWordTotalCountBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
WordCounter. prepare(Map<String,Object> topoConf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.security.auth.kerberos
Methods in org.apache.storm.security.auth.kerberos with parameters of type TopologyContext Modifier and Type Method Description void
AutoTGT. registerMetrics(TopologyContext topoContext, Map<String,Object> topoConf)
-
Uses of TopologyContext in org.apache.storm.spout
Methods in org.apache.storm.spout with parameters of type TopologyContext Modifier and Type Method Description void
CheckpointSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
ISpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
Called when a task for this component is initialized within a worker on the cluster.void
ShellSpout. open(Map<String,Object> topoConf, TopologyContext context, SpoutOutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.sql.runtime.datasource.socket.bolt
Methods in org.apache.storm.sql.runtime.datasource.socket.bolt with parameters of type TopologyContext Modifier and Type Method Description void
SocketBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.sql.runtime.datasource.socket.spout
Methods in org.apache.storm.sql.runtime.datasource.socket.spout with parameters of type TopologyContext Modifier and Type Method Description void
SocketSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.st.topology.window
Methods in org.apache.storm.st.topology.window with parameters of type TopologyContext Modifier and Type Method Description void
IncrementingSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
TimeDataIncrementingSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
TimeDataVerificationBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
VerificationBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.starter
Methods in org.apache.storm.starter with parameters of type TopologyContext Modifier and Type Method Description void
AnchoredWordCount.RandomSentenceSpout. open(Map conf, TopologyContext context, SpoutOutputCollector collector)
void
BlobStoreAPIWordCountTopology.RandomSentenceSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
FastWordCountTopology.FastRandomSentenceSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
InOrderDeliveryTest.InOrderSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
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
ReachTopology.CountAggregator. prepare(Map<String,Object> conf, TopologyContext context, BatchOutputCollector collector, Object id)
void
ReachTopology.PartialUniquer. prepare(Map<String,Object> conf, TopologyContext context, BatchOutputCollector collector, Object id)
void
ResourceAwareExampleTopology.ExclamationBolt. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.starter.bolt
Methods in org.apache.storm.starter.bolt with parameters of type TopologyContext 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 TopologyContext in org.apache.storm.starter.spout
Methods in org.apache.storm.starter.spout with parameters of type TopologyContext Modifier and Type Method Description void
RandomIntegerSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
RandomNumberGeneratorSpout. open(Map<String,Object> conf, TopologyContext context)
void
RandomSentenceSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.state
Methods in org.apache.storm.state with parameters of type TopologyContext Modifier and Type Method Description static State
StateFactory. getState(String namespace, Map<String,Object> topoConf, TopologyContext context)
Returns a new state instance using theConfig.TOPOLOGY_STATE_PROVIDER
or aInMemoryKeyValueState
if no provider is configured.State
InMemoryKeyValueStateProvider. newState(String namespace, Map<String,Object> topoConf, TopologyContext context)
State
StateProvider. newState(String namespace, Map<String,Object> topoConf, TopologyContext context)
Returns a new state instance.void
IStateSpout. open(Map<String,Object> conf, TopologyContext context)
Constructors in org.apache.storm.state with parameters of type TopologyContext Constructor Description DefaultStateSerializer(Map<String,Object> topoConf, TopologyContext context)
DefaultStateSerializer(Map<String,Object> topoConf, TopologyContext context, List<Class<?>> classesToRegister)
Constructs aDefaultStateSerializer
instance with the given list of classes registered in kryo. -
Uses of TopologyContext in org.apache.storm.task
Methods in org.apache.storm.task with parameters of type TopologyContext 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 TopologyContext in org.apache.storm.testing
Methods in org.apache.storm.testing with parameters of type TopologyContext Modifier and Type Method Description void
FeederSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
FixedTupleSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
PythonShellMetricsSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
SpoutTracker. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
TestEventLogSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
TestPlannerSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
TestWordSpout. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
ForwardingMetricsConsumer. prepare(Map<String,Object> topoConf, Object registrationArgument, TopologyContext context, IErrorReporter errorReporter)
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
TestConfBolt. prepare(Map<String,Object> conf, TopologyContext context)
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
TestWordCounter. prepare(Map<String,Object> topoConf, TopologyContext context)
void
TupleCaptureBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.topology
Methods in org.apache.storm.topology with parameters of type TopologyContext 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
IBasicBolt. prepare(Map<String,Object> topoConf, TopologyContext context)
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 TopologyContext in org.apache.storm.topology.base
Methods in org.apache.storm.topology.base with parameters of type TopologyContext Modifier and Type Method Description void
BaseBasicBolt. prepare(Map<String,Object> topoConf, TopologyContext context)
void
BaseStatefulBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
void
BaseWindowedBolt. prepare(Map<String,Object> topoConf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.trident.operation
Constructors in org.apache.storm.trident.operation with parameters of type TopologyContext Constructor Description TridentOperationContext(TopologyContext topoContext, TridentTuple.Factory factory)
-
Uses of TopologyContext in org.apache.storm.trident.planner
Methods in org.apache.storm.trident.planner with parameters of type TopologyContext Modifier and Type Method Description void
SubtopologyBolt. prepare(Map<String,Object> conf, TopologyContext context, BatchOutputCollector batchCollector)
void
TridentProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
-
Uses of TopologyContext in org.apache.storm.trident.planner.processor
Methods in org.apache.storm.trident.planner.processor with parameters of type TopologyContext Modifier and Type Method Description void
AggregateProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
void
EachProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
void
MapProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
void
MultiReducerProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
void
PartitionPersistProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
void
ProjectedProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
void
StateQueryProcessor. prepare(Map<String,Object> conf, TopologyContext context, TridentContext tridentContext)
-
Uses of TopologyContext in org.apache.storm.trident.spout
Constructors in org.apache.storm.trident.spout with parameters of type TopologyContext Constructor Description Coordinator(Map<String,Object> conf, TopologyContext context)
Emitter(String txStateId, Map<String,Object> conf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.trident.testing
Methods in org.apache.storm.trident.testing with parameters of type TopologyContext Modifier and Type Method Description ITridentSpout.BatchCoordinator<Map<Integer,List<List<Object>>>>
FeederBatchSpout. getCoordinator(String txStateId, Map<String,Object> conf, TopologyContext context)
ITridentSpout.BatchCoordinator<Map<Integer,List<List<Object>>>>
FeederCommitterBatchSpout. getCoordinator(String txStateId, Map<String,Object> conf, TopologyContext context)
ITridentSpout.Emitter<Map<Integer,List<List<Object>>>>
FeederBatchSpout. getEmitter(String txStateId, Map<String,Object> conf, TopologyContext context)
ICommitterTridentSpout.Emitter
FeederCommitterBatchSpout. getEmitter(String txStateId, Map<String,Object> conf, TopologyContext context)
void
FixedBatchSpout. open(Map<String,Object> conf, TopologyContext context)
-
Uses of TopologyContext in org.apache.storm.trident.topology
Methods in org.apache.storm.trident.topology with parameters of type TopologyContext Modifier and Type Method Description void
MasterBatchCoordinator. open(Map<String,Object> conf, TopologyContext context, SpoutOutputCollector collector)
void
ITridentBatchBolt. prepare(Map<String,Object> conf, TopologyContext context, BatchOutputCollector collector)
void
TridentBoltExecutor. prepare(Map<String,Object> conf, TopologyContext context, OutputCollector collector)
-
Uses of TopologyContext in org.apache.storm.trident.windowing
Methods in org.apache.storm.trident.windowing with parameters of type TopologyContext Modifier and Type Method Description void
WindowTridentProcessor. prepare(Map<String,Object> topoConf, TopologyContext context, TridentContext tridentContext)
-
Uses of TopologyContext in org.apache.storm.utils
Methods in org.apache.storm.utils with parameters of type TopologyContext Modifier and Type Method Description Number
ShellProcess. launch(Map<String,Object> conf, TopologyContext context)
Number
ShellProcess. launch(Map<String,Object> conf, TopologyContext context, boolean changeDirectory)
void
DefaultShellLogHandler. setUpContext(Class<?> ownerCls, ShellProcess process, TopologyContext context)
This default implementation saves theShellProcess
so it can output the process info string later.void
ShellLogHandler. setUpContext(Class<?> ownerCls, ShellProcess process, TopologyContext context)
Called at least once beforeShellLogHandler.log(org.apache.storm.multilang.ShellMsg)
for each spout and bolt.
-