Class AbstractSubtaskAttemptHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters>
- 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<R,M>
-
- org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler<R,M>
-
- org.apache.flink.runtime.rest.handler.job.AbstractSubtaskAttemptHandler<R,M>
-
- Type Parameters:
R- the response typeM- the message parameters type
- All Implemented Interfaces:
AutoCloseable,org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandler,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler,org.apache.flink.util.AutoCloseableAsync
- Direct Known Subclasses:
SubtaskExecutionAttemptAccumulatorsHandler,SubtaskExecutionAttemptDetailsHandler
public abstract class AbstractSubtaskAttemptHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters> extends AbstractSubtaskHandler<R,M>
Base class for request handlers whose response depends on a specific attempt (defined via the "SubtaskAttemptPathParameter.KEY" of a specific subtask (defined via the "SubtaskIndexPathParameter.KEY" in a specific job vertex, (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter).
-
-
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 Modifier Constructor Description protectedAbstractSubtaskAttemptHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,R,M> messageHeaders, ExecutionGraphCache executionGraphCache, Executor executor)Instantiates a new Abstract job vertex handler.
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Modifier and Type Method Description protected abstract RhandleRequest(HandlerRequest<EmptyRequestBody> request, AccessExecution execution)Called for each request after the correspondingAccessExecutionhas been retrieved from theAccessExecutionVertex.protected RhandleRequest(HandlerRequest<EmptyRequestBody> request, AccessExecutionVertex executionVertex)Called for each request after the correspondingAccessExecutionVertexhas been retrieved from theAccessExecutionJobVertex.-
Methods inherited from class org.apache.flink.runtime.rest.handler.job.AbstractSubtaskHandler
handleRequest
-
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
-
AbstractSubtaskAttemptHandler
protected AbstractSubtaskAttemptHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,R,M> messageHeaders, ExecutionGraphCache executionGraphCache, Executor executor)
Instantiates a new Abstract job vertex handler.- Parameters:
leaderRetriever- the leader retrievertimeout- the timeoutresponseHeaders- the response headersmessageHeaders- the message headersexecutionGraphCache- the execution graph cacheexecutor- the executor
-
-
Method Detail
-
handleRequest
protected R handleRequest(HandlerRequest<EmptyRequestBody> request, AccessExecutionVertex executionVertex) throws RestHandlerException
Description copied from class:AbstractSubtaskHandlerCalled for each request after the correspondingAccessExecutionVertexhas been retrieved from theAccessExecutionJobVertex.- Specified by:
handleRequestin classAbstractSubtaskHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters>- Parameters:
request- the requestexecutionVertex- the execution vertex- Returns:
- the response
- Throws:
RestHandlerException- the rest handler exception
-
handleRequest
protected abstract R handleRequest(HandlerRequest<EmptyRequestBody> request, AccessExecution execution) throws RestHandlerException
Called for each request after the correspondingAccessExecutionhas been retrieved from theAccessExecutionVertex.- Parameters:
request- the requestexecution- the execution- Returns:
- the response
- Throws:
RestHandlerException- the rest handler exception
-
-