Package | Description |
---|---|
org.apache.storm.daemon.metrics | |
org.apache.storm.daemon.worker | |
org.apache.storm.executor |
Modifier and Type | Method and Description |
---|---|
static void |
BuiltinMetricsUtil.registerQueueMetrics(Map<String,JCQueue> queues,
Map<String,Object> topoConf,
TopologyContext context) |
Modifier and Type | Method and Description |
---|---|
JCQueue |
WorkerState.getTransferQueue() |
Modifier and Type | Method and Description |
---|---|
Map<List<Long>,JCQueue> |
WorkerState.getExecutorReceiveQueueMap() |
Map<Integer,JCQueue> |
WorkerState.getLocalReceiveQueues() |
Constructor and Description |
---|
BackPressureTracker(String workerId,
Map<Integer,JCQueue> localTasksToQueues) |
Modifier and Type | Field and Description |
---|---|
protected JCQueue |
Executor.receiveQueue |
Modifier and Type | Method and Description |
---|---|
JCQueue |
ExecutorTransfer.getLocalQueue(AddressedTuple tuple) |
JCQueue |
ExecutorShutdown.getReceiveQueue() |
JCQueue |
IRunningExecutor.getReceiveQueue() |
JCQueue |
Executor.getReceiveQueue() |
Modifier and Type | Method and Description |
---|---|
boolean |
ExecutorTransfer.tryTransferLocal(AddressedTuple tuple,
JCQueue localQueue,
Queue<AddressedTuple> pendingEmits)
Adds tuple to localQueue (if overflow is empty).
|
Constructor and Description |
---|
ExecutorShutdown(Executor executor,
List<Utils.SmartThread> threads,
ArrayList<Task> taskDatas,
JCQueue recvQueue) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.