Uses of Interface
org.apache.storm.task.IMetricsContext
Package
Description
ElasticSearch Trident example classes.
-
Uses of IMetricsContext in org.apache.storm.elasticsearch.trident
-
Uses of IMetricsContext in org.apache.storm.hdfs.trident
-
Uses of IMetricsContext in org.apache.storm.hive.trident
-
Uses of IMetricsContext in org.apache.storm.jdbc.trident.state
-
Uses of IMetricsContext in org.apache.storm.jms.trident
-
Uses of IMetricsContext in org.apache.storm.kafka.trident
-
Uses of IMetricsContext in org.apache.storm.redis.trident.state
Modifier and TypeMethodDescriptionRedisClusterMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) RedisClusterState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) RedisMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) RedisState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) -
Uses of IMetricsContext in org.apache.storm.starter.trident
Modifier and TypeMethodDescriptionDebugMemoryMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) TridentReach.StaticSingleKeyMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) -
Uses of IMetricsContext in org.apache.storm.task
Modifier and TypeClassDescriptionclass
A `TopologyContext` is given to bolts and spouts in their `prepare()` and `open()` methods, respectively. -
Uses of IMetricsContext in org.apache.storm.trident.operation
-
Uses of IMetricsContext in org.apache.storm.trident.state
-
Uses of IMetricsContext in org.apache.storm.trident.testing
-
Uses of IMetricsContext in org.apache.storm.trident.windowing