Class JarPlanHandler

  • 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

    public class JarPlanHandler
    extends org.apache.flink.runtime.rest.handler.AbstractRestHandler<org.apache.flink.runtime.webmonitor.RestfulGateway,​JarPlanRequestBody,​org.apache.flink.runtime.rest.messages.JobPlanInfo,​org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters>
    This handler handles requests to fetch the plan for a jar.
    • Nested Class Summary

      • Nested classes/interfaces inherited from interface org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandler

        org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandler.Sharable
    • 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
      JarPlanHandler​(org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.webmonitor.RestfulGateway> leaderRetriever, Duration timeout, Map<String,​String> responseHeaders, org.apache.flink.runtime.rest.messages.MessageHeaders<JarPlanRequestBody,​org.apache.flink.runtime.rest.messages.JobPlanInfo,​org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters> messageHeaders, Path jarDir, org.apache.flink.configuration.Configuration configuration, Executor executor)  
      JarPlanHandler​(org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.webmonitor.RestfulGateway> leaderRetriever, Duration timeout, Map<String,​String> responseHeaders, org.apache.flink.runtime.rest.messages.MessageHeaders<JarPlanRequestBody,​org.apache.flink.runtime.rest.messages.JobPlanInfo,​org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters> messageHeaders, Path jarDir, org.apache.flink.configuration.Configuration configuration, Executor executor, Function<org.apache.flink.runtime.jobgraph.JobGraph,​org.apache.flink.runtime.rest.messages.JobPlanInfo> planGenerator)  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      protected CompletableFuture<org.apache.flink.runtime.rest.messages.JobPlanInfo> handleRequest​(org.apache.flink.runtime.rest.handler.HandlerRequest<JarPlanRequestBody> request, org.apache.flink.runtime.webmonitor.RestfulGateway gateway)  
      • 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
      • Methods inherited from interface org.apache.flink.util.AutoCloseableAsync

        close
      • Methods inherited from interface org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandler

        handlerAdded, handlerRemoved
    • Constructor Detail

      • JarPlanHandler

        public JarPlanHandler​(org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.webmonitor.RestfulGateway> leaderRetriever,
                              Duration timeout,
                              Map<String,​String> responseHeaders,
                              org.apache.flink.runtime.rest.messages.MessageHeaders<JarPlanRequestBody,​org.apache.flink.runtime.rest.messages.JobPlanInfo,​org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters> messageHeaders,
                              Path jarDir,
                              org.apache.flink.configuration.Configuration configuration,
                              Executor executor)
      • JarPlanHandler

        public JarPlanHandler​(org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.webmonitor.RestfulGateway> leaderRetriever,
                              Duration timeout,
                              Map<String,​String> responseHeaders,
                              org.apache.flink.runtime.rest.messages.MessageHeaders<JarPlanRequestBody,​org.apache.flink.runtime.rest.messages.JobPlanInfo,​org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters> messageHeaders,
                              Path jarDir,
                              org.apache.flink.configuration.Configuration configuration,
                              Executor executor,
                              Function<org.apache.flink.runtime.jobgraph.JobGraph,​org.apache.flink.runtime.rest.messages.JobPlanInfo> planGenerator)
    • Method Detail

      • handleRequest

        protected CompletableFuture<org.apache.flink.runtime.rest.messages.JobPlanInfo> handleRequest​(@Nonnull
                                                                                                      org.apache.flink.runtime.rest.handler.HandlerRequest<JarPlanRequestBody> request,
                                                                                                      @Nonnull
                                                                                                      org.apache.flink.runtime.webmonitor.RestfulGateway gateway)
                                                                                               throws org.apache.flink.runtime.rest.handler.RestHandlerException
        Specified by:
        handleRequest in class org.apache.flink.runtime.rest.handler.AbstractRestHandler<org.apache.flink.runtime.webmonitor.RestfulGateway,​JarPlanRequestBody,​org.apache.flink.runtime.rest.messages.JobPlanInfo,​org.apache.flink.runtime.webmonitor.handlers.JarPlanMessageParameters>
        Throws:
        org.apache.flink.runtime.rest.handler.RestHandlerException