public class WebSubmissionExtension extends Object implements org.apache.flink.runtime.webmonitor.WebMonitorExtension
Constructor and Description |
---|
WebSubmissionExtension(org.apache.flink.configuration.Configuration configuration,
org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.dispatcher.DispatcherGateway> leaderRetriever,
Map<String,String> responseHeaders,
CompletableFuture<String> localAddressFuture,
Path jarDir,
Executor executor,
org.apache.flink.api.common.time.Time timeout) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
closeAsync() |
Collection<org.apache.flink.api.java.tuple.Tuple2<org.apache.flink.runtime.rest.handler.RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> |
getHandlers() |
public WebSubmissionExtension(org.apache.flink.configuration.Configuration configuration, org.apache.flink.runtime.webmonitor.retriever.GatewayRetriever<? extends org.apache.flink.runtime.dispatcher.DispatcherGateway> leaderRetriever, Map<String,String> responseHeaders, CompletableFuture<String> localAddressFuture, Path jarDir, Executor executor, org.apache.flink.api.common.time.Time timeout) throws Exception
Exception
public CompletableFuture<Void> closeAsync()
closeAsync
in interface org.apache.flink.util.AutoCloseableAsync
public Collection<org.apache.flink.api.java.tuple.Tuple2<org.apache.flink.runtime.rest.handler.RestHandlerSpecification,org.apache.flink.shaded.netty4.io.netty.channel.ChannelInboundHandler>> getHandlers()
getHandlers
in interface org.apache.flink.runtime.webmonitor.WebMonitorExtension
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.