Uses of Interface
org.apache.flink.runtime.dispatcher.DispatcherGateway
-
-
Uses of DispatcherGateway in org.apache.flink.runtime.dispatcher
Classes in org.apache.flink.runtime.dispatcher that implement DispatcherGateway Modifier and Type Class Description class
Dispatcher
Base class for the Dispatcher component.class
StandaloneDispatcher
Methods in org.apache.flink.runtime.dispatcher with parameters of type DispatcherGateway Modifier and Type Method Description DispatcherBootstrap
DispatcherBootstrapFactory. create(DispatcherGateway dispatcher, org.apache.flink.util.concurrent.ScheduledExecutor scheduledExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler errorHandler)
Constructor parameters in org.apache.flink.runtime.dispatcher with type arguments of type DispatcherGateway Constructor Description DispatcherRestEndpoint(GatewayRetriever<DispatcherGateway> leaderRetriever, org.apache.flink.configuration.Configuration clusterConfiguration, RestHandlerConfiguration restConfiguration, GatewayRetriever<ResourceManagerGateway> resourceManagerRetriever, TransientBlobService transientBlobService, ScheduledExecutorService executor, MetricFetcher metricFetcher, LeaderElection leaderElection, ExecutionGraphCache executionGraphCache, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler)
-
Uses of DispatcherGateway in org.apache.flink.runtime.dispatcher.runner
Methods in org.apache.flink.runtime.dispatcher.runner that return DispatcherGateway Modifier and Type Method Description DispatcherGateway
AbstractDispatcherLeaderProcess.DispatcherGatewayService. getGateway()
DispatcherGateway
DefaultDispatcherGatewayService. getGateway()
Methods in org.apache.flink.runtime.dispatcher.runner that return types with arguments of type DispatcherGateway Modifier and Type Method Description CompletableFuture<DispatcherGateway>
AbstractDispatcherLeaderProcess. getDispatcherGateway()
CompletableFuture<DispatcherGateway>
StoppedDispatcherLeaderProcess. getDispatcherGateway()
-
Uses of DispatcherGateway in org.apache.flink.runtime.minicluster
Methods in org.apache.flink.runtime.minicluster that return types with arguments of type DispatcherGateway Modifier and Type Method Description protected CompletableFuture<DispatcherGateway>
MiniCluster. getDispatcherGatewayFuture()
-
Uses of DispatcherGateway in org.apache.flink.runtime.rest
Methods in org.apache.flink.runtime.rest that return types with arguments of type DispatcherGateway Modifier and Type Method Description WebMonitorEndpoint<DispatcherGateway>
SessionRestEndpointFactory. createRestEndpoint(org.apache.flink.configuration.Configuration configuration, LeaderGatewayRetriever<DispatcherGateway> dispatcherGatewayRetriever, LeaderGatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever, TransientBlobService transientBlobService, ScheduledExecutorService executor, MetricFetcher metricFetcher, LeaderElection leaderElection, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler)
Method parameters in org.apache.flink.runtime.rest with type arguments of type DispatcherGateway Modifier and Type Method Description WebMonitorEndpoint<RestfulGateway>
JobRestEndpointFactory. createRestEndpoint(org.apache.flink.configuration.Configuration configuration, LeaderGatewayRetriever<DispatcherGateway> dispatcherGatewayRetriever, LeaderGatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever, TransientBlobService transientBlobService, ScheduledExecutorService executor, MetricFetcher metricFetcher, LeaderElection leaderElection, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler)
WebMonitorEndpoint<T>
RestEndpointFactory. createRestEndpoint(org.apache.flink.configuration.Configuration configuration, LeaderGatewayRetriever<DispatcherGateway> dispatcherGatewayRetriever, LeaderGatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever, TransientBlobService transientBlobService, ScheduledExecutorService executor, MetricFetcher metricFetcher, LeaderElection leaderElection, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler)
WebMonitorEndpoint<DispatcherGateway>
SessionRestEndpointFactory. createRestEndpoint(org.apache.flink.configuration.Configuration configuration, LeaderGatewayRetriever<DispatcherGateway> dispatcherGatewayRetriever, LeaderGatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever, TransientBlobService transientBlobService, ScheduledExecutorService executor, MetricFetcher metricFetcher, LeaderElection leaderElection, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler)
-
Uses of DispatcherGateway in org.apache.flink.runtime.rest.handler.job
Methods in org.apache.flink.runtime.rest.handler.job with parameters of type DispatcherGateway Modifier and Type Method Description protected CompletableFuture<JobSubmitResponseBody>
JobSubmitHandler. handleRequest(HandlerRequest<JobSubmitRequestBody> request, DispatcherGateway gateway)
Constructor parameters in org.apache.flink.runtime.rest.handler.job with type arguments of type DispatcherGateway Constructor Description JobSubmitHandler(GatewayRetriever<? extends DispatcherGateway> leaderRetriever, Duration timeout, Map<String,String> headers, Executor executor, org.apache.flink.configuration.Configuration configuration)
-
Uses of DispatcherGateway in org.apache.flink.runtime.webmonitor
Method parameters in org.apache.flink.runtime.webmonitor with type arguments of type DispatcherGateway Modifier and Type Method Description static WebMonitorExtension
WebMonitorUtils. loadWebSubmissionExtension(GatewayRetriever<? extends DispatcherGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, CompletableFuture<String> localAddressFuture, Path uploadDir, Executor executor, org.apache.flink.configuration.Configuration configuration)
Loads theWebMonitorExtension
which enables web submission.
-