Package | Description |
---|---|
org.apache.storm.daemon.worker | |
org.apache.storm.messaging | |
org.apache.storm.messaging.netty | |
org.apache.storm.metrics2 | |
org.apache.storm.task | |
org.apache.storm.utils |
Modifier and Type | Method and Description |
---|---|
StormMetricRegistry |
WorkerState.getMetricRegistry() |
Constructor and Description |
---|
BackPressureTracker(String workerId,
Map<Integer,JCQueue> localTasksToQueues,
StormMetricRegistry metricRegistry,
Map<Integer,String> taskToComponent) |
WorkerState(Map<String,Object> conf,
IContext mqContext,
String topologyId,
String assignmentId,
Supplier<SupervisorIfaceFactory> supervisorIfaceSupplier,
int port,
String workerId,
Map<String,Object> topologyConf,
IStateStorage stateStorage,
IStormClusterState stormClusterState,
Collection<IAutoCredentials> autoCredentials,
StormMetricRegistry metricRegistry,
Credentials initialCredentials) |
Modifier and Type | Method and Description |
---|---|
static IContext |
TransportFactory.makeContext(Map<String,Object> topoConf,
StormMetricRegistry metricRegistry) |
default void |
IContext.prepare(Map<String,Object> topoConf,
StormMetricRegistry metricRegistry)
This method is invoked at the startup of messaging plugin.
|
Modifier and Type | Method and Description |
---|---|
void |
Context.prepare(Map<String,Object> topoConf,
StormMetricRegistry metricRegistry) |
Constructor and Description |
---|
TaskMetricDimensions(int taskId,
String componentId,
String streamId,
StormMetricRegistry metricRegistry) |
TaskMetrics(WorkerTopologyContext context,
String componentId,
Integer taskid,
StormMetricRegistry metricRegistry,
Map<String,Object> topoConf) |
Constructor and Description |
---|
TopologyContext(StormTopology topology,
Map<String,Object> topoConf,
Map<Integer,String> taskToComponent,
Map<String,List<Integer>> componentToSortedTasks,
Map<String,Map<String,Fields>> componentToStreamToFields,
Map<String,Long> blobToLastKnownVersionShared,
String stormId,
String codeDir,
String pidDir,
Integer taskId,
Integer workerPort,
List<Integer> workerTasks,
Map<String,Object> defaultResources,
Map<String,Object> userResources,
Map<String,Object> executorData,
Map<Integer,Map<Integer,Map<String,IMetric>>> registeredMetrics,
AtomicBoolean openOrPrepareWasCalled,
StormMetricRegistry metricRegistry) |
Constructor and Description |
---|
JCQueue(String queueName,
String metricNamePrefix,
int size,
int overflowLimit,
int producerBatchSz,
IWaitStrategy backPressureWaitStrategy,
String topologyId,
String componentId,
List<Integer> taskIds,
int port,
StormMetricRegistry metricRegistry) |
JCQueueMetrics(String metricNamePrefix,
String topologyId,
String componentId,
int taskId,
int port,
StormMetricRegistry metricRegistry,
org.apache.storm.shade.org.jctools.queues.MpscArrayQueue<Object> receiveQ,
org.apache.storm.shade.org.jctools.queues.MpscUnboundedArrayQueue<Object> overflowQ) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.