R
- type of the responsepublic abstract class AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters> extends AbstractCheckpointStatsHandler<R,M>
log, MAPPER
leaderRetriever, logger, responseHeaders, timeout
Modifier | Constructor and Description |
---|---|
protected |
AbstractCheckpointHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever,
Time timeout,
Map<String,String> responseHeaders,
MessageHeaders<EmptyRequestBody,R,M> messageHeaders,
Executor executor,
org.apache.flink.shaded.guava31.com.google.common.cache.Cache<JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache,
CheckpointStatsCache checkpointStatsCache) |
Modifier and Type | Method and Description |
---|---|
protected abstract R |
handleCheckpointRequest(HandlerRequest<EmptyRequestBody> request,
AbstractCheckpointStats checkpointStats)
Called for each request with the corresponding
AbstractCheckpointStats instance. |
protected R |
handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody> request,
CheckpointStatsSnapshot checkpointStatsSnapshot) |
handleRequest
getMessageHeaders, respondToRequest
closeAsync, closeHandlerAsync, respondAsLeader
channelRead0
acceptInboundMessage, channelRead
channelActive, channelInactive, channelReadComplete, channelRegistered, channelUnregistered, channelWritabilityChanged, exceptionCaught, userEventTriggered
ensureNotSharable, handlerAdded, handlerRemoved, isSharable
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
close
protected AbstractCheckpointHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Time timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,R,M> messageHeaders, Executor executor, org.apache.flink.shaded.guava31.com.google.common.cache.Cache<JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, CheckpointStatsCache checkpointStatsCache)
protected R handleCheckpointStatsRequest(HandlerRequest<EmptyRequestBody> request, CheckpointStatsSnapshot checkpointStatsSnapshot) throws RestHandlerException
handleCheckpointStatsRequest
in class AbstractCheckpointStatsHandler<R extends ResponseBody,M extends CheckpointMessageParameters>
RestHandlerException
protected abstract R handleCheckpointRequest(HandlerRequest<EmptyRequestBody> request, AbstractCheckpointStats checkpointStats) throws RestHandlerException
AbstractCheckpointStats
instance.request
- for further informationcheckpointStats
- for which the handler is calledRestHandlerException
- if the handler could not handle the requestCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.