public class ThreadInfoRequestCoordinator extends TaskStatsRequestCoordinator<Map<ExecutionAttemptID,Collection<ThreadInfoSample>>,VertexThreadInfoStats>
TaskStatsRequestCoordinator.PendingStatsRequest<T,V>
executor, isShutDown, lock, log, NUM_GHOST_SAMPLE_IDS, pendingRequests, recentPendingRequestIds, requestIdCounter, requestTimeout
Constructor and Description |
---|
ThreadInfoRequestCoordinator(Executor executor,
java.time.Duration requestTimeout)
Creates a new coordinator for the job.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<VertexThreadInfoStats> |
triggerThreadInfoRequest(Map<org.apache.flink.shaded.guava30.com.google.common.collect.ImmutableSet<ExecutionAttemptID>,CompletableFuture<TaskExecutorThreadInfoGateway>> executionsWithGateways,
int numSamples,
java.time.Duration delayBetweenSamples,
int maxStackTraceDepth)
Triggers collection of thread info stats of a job vertex by combining thread info responses
from given subtasks.
|
getNumberOfPendingRequests, handleFailedResponse, handleSuccessfulResponse, shutDown
public ThreadInfoRequestCoordinator(Executor executor, java.time.Duration requestTimeout)
executor
- Used to execute the futures.requestTimeout
- Time out after the expected sampling duration. This is added to the
expected duration of a request, which is determined by the number of samples and the
delay between each sample.public CompletableFuture<VertexThreadInfoStats> triggerThreadInfoRequest(Map<org.apache.flink.shaded.guava30.com.google.common.collect.ImmutableSet<ExecutionAttemptID>,CompletableFuture<TaskExecutorThreadInfoGateway>> executionsWithGateways, int numSamples, java.time.Duration delayBetweenSamples, int maxStackTraceDepth)
numSamples
, collected with delayBetweenSamples
milliseconds delay between them.executionsWithGateways
- Execution attempts together with TaskExecutors running them.numSamples
- Number of thread info samples to collect from each subtask.delayBetweenSamples
- Delay between consecutive samples (ms).maxStackTraceDepth
- Maximum depth of the stack traces collected within thread info
samples.Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.