Uses of Class
org.apache.storm.task.TopologyContext
Package
Description
ElasticSearch examples classes.
ElasticSearch Trident example classes.
-
Uses of TopologyContext in org.apache.storm
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
JoinBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of TopologyContext in org.apache.storm.clojure
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
Acker.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of TopologyContext in org.apache.storm.daemon.metrics
Modifier and TypeMethodDescriptionstatic 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
Modifier and TypeMethodDescriptionvoid
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.elasticsearch.bolt
Modifier and TypeMethodDescriptionvoid
EsIndexTopology.UserDataSpout.open
(Map<String, Object> config, TopologyContext context, SpoutOutputCollector collectorArg) Acquirescollector
and initializespending
.void
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 TopologyContext in org.apache.storm.elasticsearch.trident
Modifier and TypeMethodDescriptionvoid
TridentEsTopology.FixedBatchSpout.open
(Map<String, Object> conf, TopologyContext context) Opens the spout. -
Uses of TopologyContext 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) void
WordCounter.prepare
(Map<String, Object> topoConf, TopologyContext context) -
Uses of TopologyContext 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) void
HdfsFileTopology.SentenceSpout.open
(Map<String, Object> config, TopologyContext context, SpoutOutputCollector collector) void
SequenceFileTopology.SentenceSpout.open
(Map<String, Object> config, TopologyContext context, SpoutOutputCollector 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 TopologyContext in org.apache.storm.hdfs.bolt.format
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
FixedBatchSpout.open
(Map<String, Object> conf, TopologyContext context) -
Uses of TopologyContext in org.apache.storm.hive.bolt
Modifier and TypeMethodDescriptionvoid
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) -
Uses of TopologyContext in org.apache.storm.hive.trident
Modifier and TypeMethodDescriptionvoid
TridentHiveTopology.FixedBatchSpout.open
(Map<String, Object> conf, TopologyContext context) -
Uses of TopologyContext in org.apache.storm.hooks
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
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 TopologyContext in org.apache.storm.jdbc.spout
Modifier and TypeMethodDescriptionvoid
UserSpout.open
(Map<String, Object> conf, TopologyContext context, SpoutOutputCollector collector) -
Uses of TopologyContext in org.apache.storm.jms.bolt
Modifier and TypeMethodDescriptionvoid
JmsBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) Initializes JMS resources. -
Uses of TopologyContext in org.apache.storm.jms.example
Modifier and TypeMethodDescriptionvoid
GenericBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of TopologyContext in org.apache.storm.jms.spout
Modifier and TypeMethodDescriptionvoid
JmsSpout.open
(Map<String, Object> conf, TopologyContext context, SpoutOutputCollector spoutOutputCollector) ISpout
implementation. -
Uses of TopologyContext in org.apache.storm.jms.trident
Modifier and TypeMethodDescriptionTridentJmsSpout.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) TridentJmsSpout.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) -
Uses of TopologyContext in org.apache.storm.kafka.bolt
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
ModifierConstructorDescriptionCommitMetadataManager
(TopologyContext context, KafkaSpoutConfig.ProcessingGuarantee processingGuarantee) Create a manager with the given context. -
Uses of TopologyContext in org.apache.storm.kafka.spout.metrics2
ModifierConstructorDescriptionKafkaOffsetMetricManager
(Supplier<Map<org.apache.kafka.common.TopicPartition, OffsetManager>> offsetManagerSupplier, Supplier<org.apache.kafka.clients.consumer.Consumer<K, V>> consumerSupplier, TopologyContext topologyContext) -
Uses of TopologyContext in org.apache.storm.kafka.spout.subscription
Modifier and TypeMethodDescriptionSet<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
Modifier and TypeMethodDescriptionKafkaTridentSpoutOpaque.getCoordinator
(Map<String, Object> conf, TopologyContext context) 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) ModifierConstructorDescriptionKafkaTridentSpoutEmitter
(KafkaTridentSpoutConfig<K, V> kafkaSpoutConfig, TopologyContext topologyContext) Create a new Kafka spout emitter. -
Uses of TopologyContext in org.apache.storm.lambda
Modifier and TypeMethodDescriptionvoid
LambdaSpout.open
(Map<String, Object> conf, TopologyContext context, SpoutOutputCollector collector) -
Uses of TopologyContext in org.apache.storm.loadgen
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptioncom.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
Modifier and TypeMethodDescriptionvoid
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
-
Uses of TopologyContext in org.apache.storm.perf.bolt
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
IdentityBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of TopologyContext 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 TopologyContext in org.apache.storm.redis.state
-
Uses of TopologyContext in org.apache.storm.redis.topology
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
AutoTGT.registerMetrics
(TopologyContext topoContext, Map<String, Object> topoConf) -
Uses of TopologyContext in org.apache.storm.spout
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
SocketBolt.prepare
(Map<String, Object> topoConf, TopologyContext context, OutputCollector collector) -
Uses of TopologyContext in org.apache.storm.sql.runtime.datasource.socket.spout
Modifier and TypeMethodDescriptionvoid
SocketSpout.open
(Map<String, Object> conf, TopologyContext context, SpoutOutputCollector collector) -
Uses of TopologyContext in org.apache.storm.st.topology.window
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
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 TopologyContext in org.apache.storm.starter.spout
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionstatic State
Returns a new state instance using theConfig.TOPOLOGY_STATE_PROVIDER
or aInMemoryKeyValueState
if no provider is configured.InMemoryKeyValueStateProvider.newState
(String namespace, Map<String, Object> topoConf, TopologyContext context) Returns a new state instance.void
IStateSpout.open
(Map<String, Object> conf, TopologyContext context) ModifierConstructorDescriptionDefaultStateSerializer
(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
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 TopologyContext in org.apache.storm.testing
Modifier and TypeMethodDescriptionvoid
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
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
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
Modifier and TypeMethodDescriptionvoid
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
ModifierConstructorDescriptionTridentOperationContext
(TopologyContext topoContext, TridentTuple.Factory factory) -
Uses of TopologyContext in org.apache.storm.trident.planner
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionBatchSpoutExecutor.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) IOpaquePartitionedTridentSpout.getCoordinator
(Map<String, Object> conf, TopologyContext context) IPartitionedTridentSpout.getCoordinator
(Map<String, Object> conf, TopologyContext context) ITridentSpout.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) The coordinator for a TransactionalSpout runs in a single thread and indicates when batches of tuples should be emitted.OpaquePartitionedTridentSpoutExecutor.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) PartitionedTridentSpoutExecutor.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) RichSpoutBatchExecutor.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) BatchSpoutExecutor.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) ICommitterTridentSpout.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) IOpaquePartitionedTridentSpout.getEmitter
(Map<String, Object> conf, TopologyContext context) IPartitionedTridentSpout.getEmitter
(Map<String, Object> conf, TopologyContext context) ITridentSpout.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) The emitter for a TransactionalSpout runs as many tasks across the cluster.OpaquePartitionedTridentSpoutExecutor.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) PartitionedTridentSpoutExecutor.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) RichSpoutBatchExecutor.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) void
IBatchSpout.open
(Map<String, Object> conf, TopologyContext context) void
RichSpoutBatchTriggerer.open
(Map<String, Object> conf, TopologyContext context, SpoutOutputCollector collector) void
TridentSpoutCoordinator.prepare
(Map<String, Object> conf, TopologyContext context) void
TridentSpoutExecutor.prepare
(Map<String, Object> conf, TopologyContext context, BatchOutputCollector collector) -
Uses of TopologyContext in org.apache.storm.trident.testing
Modifier and TypeMethodDescriptionFeederBatchSpout.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) FeederCommitterBatchSpout.getCoordinator
(String txStateId, Map<String, Object> conf, TopologyContext context) FeederBatchSpout.getEmitter
(String txStateId, Map<String, Object> conf, TopologyContext context) 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
Modifier and TypeMethodDescriptionvoid
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
Modifier and TypeMethodDescriptionvoid
WindowTridentProcessor.prepare
(Map<String, Object> topoConf, TopologyContext context, TridentContext tridentContext) -
Uses of TopologyContext in org.apache.storm.utils
Modifier and TypeMethodDescriptionShellProcess.launch
(Map<String, Object> conf, TopologyContext context) 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.