Class JarRunHandler
- 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<org.apache.flink.runtime.rest.handler.router.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<org.apache.flink.runtime.dispatcher.DispatcherGateway,JarRunRequestBody,JarRunResponseBody,JarRunMessageParameters>
-
- org.apache.flink.runtime.webmonitor.handlers.JarRunHandler
-
- 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 JarRunHandler extends org.apache.flink.runtime.rest.handler.AbstractRestHandler<org.apache.flink.runtime.dispatcher.DispatcherGateway,JarRunRequestBody,JarRunResponseBody,JarRunMessageParameters>
Handler to submit jobs uploaded via the Web UI.
-
-
Constructor Summary
Constructors Constructor Description JarRunHandler(org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.dispatcher.DispatcherGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, org.apache.flink.runtime.rest.messages.MessageHeaders<JarRunRequestBody,JarRunResponseBody,JarRunMessageParameters> messageHeaders, Path jarDir, org.apache.flink.configuration.Configuration configuration, Executor executor, Supplier<org.apache.flink.client.deployment.application.ApplicationRunner> applicationRunnerSupplier)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description CompletableFuture<JarRunResponseBody>handleRequest(org.apache.flink.runtime.rest.handler.HandlerRequest<JarRunRequestBody> request, org.apache.flink.runtime.dispatcher.DispatcherGateway 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
-
-
-
-
Constructor Detail
-
JarRunHandler
public JarRunHandler(org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.dispatcher.DispatcherGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, org.apache.flink.runtime.rest.messages.MessageHeaders<JarRunRequestBody,JarRunResponseBody,JarRunMessageParameters> messageHeaders, Path jarDir, org.apache.flink.configuration.Configuration configuration, Executor executor, Supplier<org.apache.flink.client.deployment.application.ApplicationRunner> applicationRunnerSupplier)
-
-
Method Detail
-
handleRequest
@VisibleForTesting public CompletableFuture<JarRunResponseBody> handleRequest(@Nonnull org.apache.flink.runtime.rest.handler.HandlerRequest<JarRunRequestBody> request, @Nonnull org.apache.flink.runtime.dispatcher.DispatcherGateway gateway) throws org.apache.flink.runtime.rest.handler.RestHandlerException
- Specified by:
handleRequestin classorg.apache.flink.runtime.rest.handler.AbstractRestHandler<org.apache.flink.runtime.dispatcher.DispatcherGateway,JarRunRequestBody,JarRunResponseBody,JarRunMessageParameters>- Throws:
org.apache.flink.runtime.rest.handler.RestHandlerException
-
-