Uses of Interface
org.apache.storm.task.IMetricsContext
-
-
Uses of IMetricsContext in org.apache.storm.hdfs.trident
Methods in org.apache.storm.hdfs.trident with parameters of type IMetricsContext Modifier and Type Method Description State
HdfsStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.hive.trident
Methods in org.apache.storm.hive.trident with parameters of type IMetricsContext Modifier and Type Method Description State
HiveStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
Deprecated, for removal: This API element is subject to removal in a future version.void
HiveState. prepare(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of IMetricsContext in org.apache.storm.jdbc.trident.state
Methods in org.apache.storm.jdbc.trident.state with parameters of type IMetricsContext Modifier and Type Method Description State
JdbcStateFactory. makeState(Map<String,Object> map, IMetricsContext metricsContext, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.jms.trident
Methods in org.apache.storm.jms.trident with parameters of type IMetricsContext Modifier and Type Method Description State
JmsStateFactory. makeState(Map<String,Object> map, IMetricsContext metricsContext, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.kafka.trident
Methods in org.apache.storm.kafka.trident with parameters of type IMetricsContext Modifier and Type Method Description State
TridentKafkaStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.redis.trident.state
Methods in org.apache.storm.redis.trident.state with parameters of type IMetricsContext Modifier and Type Method Description State
RedisClusterMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
RedisClusterState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
RedisMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
RedisState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.starter.trident
Methods in org.apache.storm.starter.trident with parameters of type IMetricsContext Modifier and Type Method Description State
DebugMemoryMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
TridentReach.StaticSingleKeyMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.task
Classes in org.apache.storm.task that implement IMetricsContext Modifier and Type Class Description class
TopologyContext
A `TopologyContext` is given to bolts and spouts in their `prepare()` and `open()` methods, respectively. -
Uses of IMetricsContext in org.apache.storm.trident.operation
Classes in org.apache.storm.trident.operation that implement IMetricsContext Modifier and Type Class Description class
TridentOperationContext
-
Uses of IMetricsContext in org.apache.storm.trident.state
Methods in org.apache.storm.trident.state with parameters of type IMetricsContext Modifier and Type Method Description State
StateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.trident.testing
Methods in org.apache.storm.trident.testing with parameters of type IMetricsContext Modifier and Type Method Description State
LRUMemoryMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
MemoryMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of IMetricsContext in org.apache.storm.trident.windowing
Methods in org.apache.storm.trident.windowing with parameters of type IMetricsContext Modifier and Type Method Description State
WindowsStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-