Uses of Interface
org.apache.flink.runtime.webmonitor.RestfulGateway
-
-
Uses of RestfulGateway in org.apache.flink.runtime.dispatcher
Subinterfaces of RestfulGateway in org.apache.flink.runtime.dispatcher Modifier and Type Interface Description interface
DispatcherGateway
Gateway for the Dispatcher component.Classes in org.apache.flink.runtime.dispatcher that implement RestfulGateway Modifier and Type Class Description class
Dispatcher
Base class for the Dispatcher component.class
StandaloneDispatcher
-
Uses of RestfulGateway in org.apache.flink.runtime.jobmaster
Constructor parameters in org.apache.flink.runtime.jobmaster with type arguments of type RestfulGateway Constructor Description MiniDispatcherRestEndpoint(GatewayRetriever<? extends RestfulGateway> 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 RestfulGateway in org.apache.flink.runtime.rest
Classes in org.apache.flink.runtime.rest with type parameters of type RestfulGateway Modifier and Type Interface Description interface
RestEndpointFactory<T extends RestfulGateway>
WebMonitorEndpoint
factory.Methods in org.apache.flink.runtime.rest that return types with arguments of type RestfulGateway 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)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler
Classes in org.apache.flink.runtime.rest.handler with type parameters of type RestfulGateway Modifier and Type Class Description class
AbstractHandler<T extends RestfulGateway,R extends RequestBody,M extends MessageParameters>
Super class for netty-based handlers that work withRequestBody
.class
AbstractRestHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters>
Super class for netty-based handlers that work withRequestBody
s andResponseBody
s.class
LeaderRetrievalHandler<T extends RestfulGateway>
SimpleChannelInboundHandler
which encapsulates the leader retrieval logic for the REST endpoints. -
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.async
Classes in org.apache.flink.runtime.rest.handler.async with type parameters of type RestfulGateway Modifier and Type Class Description protected class
AbstractAsynchronousOperationHandlers.StatusHandler<T extends RestfulGateway,V,M extends MessageParameters>
Handler which will be polled to retrieve the asynchronous operation's result.protected class
AbstractAsynchronousOperationHandlers.TriggerHandler<T extends RestfulGateway,B extends RequestBody,M extends MessageParameters>
Handler which is responsible for triggering an asynchronous operation. -
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.cluster
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.dataset
Methods in org.apache.flink.runtime.rest.handler.dataset with parameters of type RestfulGateway Modifier and Type Method Description protected CompletableFuture<ClusterDataSetDeleteHandlers.SerializableVoid>
ClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandler. triggerOperation(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
Constructor parameters in org.apache.flink.runtime.rest.handler.dataset with type arguments of type RestfulGateway Constructor Description ClusterDataSetDeleteStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
ClusterDataSetDeleteTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever)
ClusterDataSetListHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.job
Method parameters in org.apache.flink.runtime.rest.handler.job with type arguments of type RestfulGateway Modifier and Type Method Description static AbstractRestHandler<?,?,?,?>
JobVertexFlameGraphHandler. disabledHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.job.checkpoints
Methods in org.apache.flink.runtime.rest.handler.job.checkpoints with parameters of type RestfulGateway Modifier and Type Method Description protected CompletableFuture<R>
AbstractCheckpointStatsHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
CompletableFuture<AsynchronousOperationResult<CheckpointInfo>>
CheckpointHandlers.CheckpointStatusHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
protected CompletableFuture<TriggerResponse>
CheckpointHandlers.CheckpointTriggerHandler. handleRequest(HandlerRequest<CheckpointTriggerRequestBody> request, RestfulGateway gateway)
Constructor parameters in org.apache.flink.runtime.rest.handler.job.checkpoints with type arguments of type RestfulGateway Constructor Description AbstractCheckpointHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,R,M> messageHeaders, Executor executor, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, CheckpointStatsCache checkpointStatsCache)
AbstractCheckpointStatsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,R,M> messageHeaders, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, Executor executor)
CheckpointConfigHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,CheckpointConfigInfo,JobMessageParameters> messageHeaders, ExecutionGraphCache executionGraphCache, Executor executor)
CheckpointingStatisticsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,CheckpointingStatistics,JobMessageParameters> messageHeaders, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, Executor executor)
CheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,CheckpointStatistics,CheckpointMessageParameters> messageHeaders, Executor executor, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, CheckpointStatsCache checkpointStatsCache)
CheckpointStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
CheckpointTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
TaskCheckpointStatisticDetailsHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<EmptyRequestBody,TaskCheckpointStatisticsWithSubtaskDetails,TaskCheckpointMessageParameters> messageHeaders, Executor executor, org.apache.flink.shaded.guava32.com.google.common.cache.Cache<org.apache.flink.api.common.JobID,CompletableFuture<CheckpointStatsSnapshot>> checkpointStatsSnapshotCache, CheckpointStatsCache checkpointStatsCache)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.job.coordination
Methods in org.apache.flink.runtime.rest.handler.job.coordination with parameters of type RestfulGateway Modifier and Type Method Description protected CompletableFuture<ClientCoordinationResponseBody>
ClientCoordinationHandler. handleRequest(HandlerRequest<ClientCoordinationRequestBody> request, RestfulGateway gateway)
Constructor parameters in org.apache.flink.runtime.rest.handler.job.coordination with type arguments of type RestfulGateway Constructor Description ClientCoordinationHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders, MessageHeaders<ClientCoordinationRequestBody,ClientCoordinationResponseBody,ClientCoordinationMessageParameters> messageHeaders)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.job.metrics
Methods in org.apache.flink.runtime.rest.handler.job.metrics with parameters of type RestfulGateway Modifier and Type Method Description protected CompletableFuture<AggregatedMetricsResponseBody>
AbstractAggregatingMetricsHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
protected CompletableFuture<MetricCollectionResponseBody>
AbstractMetricsHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.job.rescaling
Methods in org.apache.flink.runtime.rest.handler.job.rescaling with parameters of type RestfulGateway Modifier and Type Method Description CompletableFuture<AsynchronousOperationResult<AsynchronousOperationInfo>>
RescalingHandlers.RescalingStatusHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
CompletableFuture<TriggerResponse>
RescalingHandlers.RescalingTriggerHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
protected CompletableFuture<Acknowledge>
RescalingHandlers.RescalingTriggerHandler. triggerOperation(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
Constructor parameters in org.apache.flink.runtime.rest.handler.job.rescaling with type arguments of type RestfulGateway Constructor Description RescalingStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
RescalingTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.job.savepoints
Methods in org.apache.flink.runtime.rest.handler.job.savepoints with parameters of type RestfulGateway Modifier and Type Method Description CompletableFuture<AsynchronousOperationResult<SavepointInfo>>
SavepointHandlers.SavepointStatusHandler. handleRequest(HandlerRequest<EmptyRequestBody> request, RestfulGateway gateway)
protected CompletableFuture<Acknowledge>
SavepointDisposalHandlers.SavepointDisposalTriggerHandler. triggerOperation(HandlerRequest<SavepointDisposalRequest> request, RestfulGateway gateway)
protected CompletableFuture<Acknowledge>
SavepointHandlers.SavepointTriggerHandler. triggerOperation(HandlerRequest<SavepointTriggerRequestBody> request, AsynchronousJobOperationKey operationKey, RestfulGateway gateway)
protected CompletableFuture<Acknowledge>
SavepointHandlers.StopWithSavepointHandler. triggerOperation(HandlerRequest<StopWithSavepointRequestBody> request, AsynchronousJobOperationKey operationKey, RestfulGateway gateway)
Constructor parameters in org.apache.flink.runtime.rest.handler.job.savepoints with type arguments of type RestfulGateway Constructor Description SavepointDisposalStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
SavepointDisposalTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
SavepointStatusHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
SavepointTriggerHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
StopWithSavepointHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.legacy
Methods in org.apache.flink.runtime.rest.handler.legacy with parameters of type RestfulGateway Modifier and Type Method Description CompletableFuture<ExecutionGraphInfo>
DefaultExecutionGraphCache. getExecutionGraphInfo(org.apache.flink.api.common.JobID jobId, RestfulGateway restfulGateway)
CompletableFuture<ExecutionGraphInfo>
ExecutionGraphCache. getExecutionGraphInfo(org.apache.flink.api.common.JobID jobId, RestfulGateway restfulGateway)
Gets theExecutionGraphInfo
for the givenJobID
and caches it. -
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.legacy.files
Classes in org.apache.flink.runtime.rest.handler.legacy.files with type parameters of type RestfulGateway Modifier and Type Class Description class
StaticFileServerHandler<T extends RestfulGateway>
Simple file server handler that serves requests to web frontend's static files, such as HTML, CSS, or JS files. -
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.legacy.metrics
Classes in org.apache.flink.runtime.rest.handler.legacy.metrics with type parameters of type RestfulGateway Modifier and Type Class Description class
MetricFetcherImpl<T extends RestfulGateway>
Implementation ofMetricFetcher
which fetches metrics from theMetricQueryServiceGateway
.Methods in org.apache.flink.runtime.rest.handler.legacy.metrics with type parameters of type RestfulGateway Modifier and Type Method Description static <T extends RestfulGateway>
MetricFetcherImpl<T>MetricFetcherImpl. fromConfiguration(org.apache.flink.configuration.Configuration configuration, MetricQueryServiceRetriever metricQueryServiceGatewayRetriever, GatewayRetriever<T> dispatcherGatewayRetriever, ExecutorService executor)
-
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.resourcemanager
Classes in org.apache.flink.runtime.rest.handler.resourcemanager with type parameters of type RestfulGateway Modifier and Type Class Description class
AbstractResourceManagerHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters>
Base class for REST handlers which need access to theResourceManager
. -
Uses of RestfulGateway in org.apache.flink.runtime.rest.handler.taskmanager
Methods in org.apache.flink.runtime.rest.handler.taskmanager with parameters of type RestfulGateway Modifier and Type Method Description protected CompletableFuture<Void>
AbstractTaskManagerFileHandler. respondToRequest(org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandlerContext ctx, org.apache.flink.shaded.netty4.io.netty.handler.codec.http.HttpRequest httpRequest, HandlerRequest<EmptyRequestBody> handlerRequest, RestfulGateway gateway)
-
Uses of RestfulGateway in org.apache.flink.runtime.webmonitor
Classes in org.apache.flink.runtime.webmonitor with type parameters of type RestfulGateway Modifier and Type Class Description class
WebMonitorEndpoint<T extends RestfulGateway>
Rest endpoint which serves the web frontend REST calls.Classes in org.apache.flink.runtime.webmonitor that implement RestfulGateway Modifier and Type Class Description class
NonLeaderRetrievalRestfulGateway
* Gateway for restful endpoints without leader retrieval logic. * *Methods in org.apache.flink.runtime.webmonitor with type parameters of type RestfulGateway Modifier and Type Method Description static <T extends RestfulGateway>
Optional<StaticFileServerHandler<T>>WebMonitorUtils. tryLoadWebContent(GatewayRetriever<? extends T> leaderRetriever, Duration timeout, File tmpDir)
Checks whether the flink-runtime-web dependency is available and if so returns a StaticFileServerHandler which can serve the static file contents.
-