Class JobVertexFlameGraphHandler
- java.lang.Object
-
- org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandlerAdapter
-
- org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandlerAdapter
-
- org.apache.flink.shaded.netty4.io.netty.channel.SimpleChannelInboundHandler<RoutedRequest>
-
- org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler<T>
-
- org.apache.flink.runtime.rest.handler.AbstractHandler<T,R,M>
-
- org.apache.flink.runtime.rest.handler.AbstractRestHandler<RestfulGateway,EmptyRequestBody,R,M>
-
- org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler<R,M>
-
- org.apache.flink.runtime.rest.handler.job.AbstractAccessExecutionGraphHandler<R,M>
-
- org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler<VertexFlameGraph,JobVertexFlameGraphParameters>
-
- org.apache.flink.runtime.rest.handler.job.JobVertexFlameGraphHandler
-
- All Implemented Interfaces:
AutoCloseable
,org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandler
,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler
,AutoCloseableAsync
public class JobVertexFlameGraphHandler extends AbstractJobVertexHandler<VertexFlameGraph,JobVertexFlameGraphParameters>
Request handler for the job vertex Flame Graph.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.rest.handler.AbstractHandler
log, MAPPER
-
Fields inherited from class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
leaderRetriever, logger, responseHeaders, timeout
-
-
Constructor Summary
Constructors Constructor Description JobVertexFlameGraphHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, ExecutionGraphCache executionGraphCache, Executor executor, VertexStatsTracker<VertexThreadInfoStats> threadInfoOperatorTracker)
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
static AbstractRestHandler<?,?,?,?>
disabledHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
protected VertexFlameGraph
handleRequest(HandlerRequest<EmptyRequestBody> request, AccessExecutionJobVertex jobVertex)
Called for each request after the correspondingAccessExecutionJobVertex
has been retrieved from theAccessExecutionGraph
.-
Methods inherited from class org.apache.flink.runtime.rest.handler.job.AbstractJobVertexHandler
handleRequest
-
Methods inherited from class org.apache.flink.runtime.rest.handler.job.AbstractAccessExecutionGraphHandler
handleRequest
-
Methods inherited from class org.apache.flink.runtime.rest.handler.job.AbstractExecutionGraphHandler
handleRequest
-
Methods inherited from class org.apache.flink.runtime.rest.handler.AbstractRestHandler
getMessageHeaders, respondToRequest
-
Methods inherited from class org.apache.flink.runtime.rest.handler.AbstractHandler
closeAsync, closeHandlerAsync, respondAsLeader
-
Methods inherited from class org.apache.flink.runtime.rest.handler.LeaderRetrievalHandler
channelRead0, getTimeout
-
Methods inherited from class org.apache.flink.shaded.netty4.io.netty.channel.SimpleChannelInboundHandler
acceptInboundMessage, channelRead
-
Methods inherited from class org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandlerAdapter
channelActive, channelInactive, channelReadComplete, channelRegistered, channelUnregistered, channelWritabilityChanged, exceptionCaught, userEventTriggered
-
Methods inherited from class org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandlerAdapter
ensureNotSharable, handlerAdded, handlerRemoved, isSharable
-
-
-
-
Constructor Detail
-
JobVertexFlameGraphHandler
public JobVertexFlameGraphHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, ExecutionGraphCache executionGraphCache, Executor executor, VertexStatsTracker<VertexThreadInfoStats> threadInfoOperatorTracker)
-
-
Method Detail
-
handleRequest
protected VertexFlameGraph handleRequest(HandlerRequest<EmptyRequestBody> request, AccessExecutionJobVertex jobVertex) throws RestHandlerException
Description copied from class:AbstractJobVertexHandler
Called for each request after the correspondingAccessExecutionJobVertex
has been retrieved from theAccessExecutionGraph
.- Specified by:
handleRequest
in classAbstractJobVertexHandler<VertexFlameGraph,JobVertexFlameGraphParameters>
- Parameters:
request
- the requestjobVertex
- the execution job vertex- Returns:
- the response
- Throws:
RestHandlerException
- if the handler could not process the request
-
disabledHandler
public static AbstractRestHandler<?,?,?,?> disabledHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
-
-