Uses of Class
org.apache.flink.runtime.rest.handler.AbstractRestHandler
-
-
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.async
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.async Modifier and Type Class Description protected classAbstractAsynchronousOperationHandlers.StatusHandler<T extends RestfulGateway,V,M extends MessageParameters>Handler which will be polled to retrieve the asynchronous operation's result.protected classAbstractAsynchronousOperationHandlers.TriggerHandler<T extends RestfulGateway,B extends RequestBody,M extends MessageParameters>Handler which is responsible for triggering an asynchronous operation. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.cluster
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.cluster Modifier and Type Class Description classClusterConfigHandlerHandler which serves the cluster's configuration.classClusterOverviewHandlerHandler which returns the cluster overview information with version.classDashboardConfigHandlerHandler which returns the dashboard configuration.classJobManagerEnvironmentHandlerHandler which serves the jobmanager's environment variables.classJobManagerLogListHandlerHandler which serves detailed JobManager log list information.classJobManagerProfilingHandlerRest handler which serves the profiling info from the JobManager.classJobManagerProfilingListHandlerRest handler which serves the profiling list from the JobManager.classJobManagerThreadDumpHandlerRest handler which serves the thread dump info from the JobManager.classShutdownHandlerREST handler which allows to shut down the cluster. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.dataset
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.dataset Modifier and Type Class Description classClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandlerAbstractAsynchronousOperationHandlers.StatusHandlerimplementation for the cluster data set delete operation.classClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandlerAbstractAsynchronousOperationHandlers.TriggerHandlerimplementation for the cluster data set delete operation.classClusterDataSetListHandlerHandler forClusterDataSetListHeaders. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job Modifier and Type Class Description classAbstractAccessExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters>AbstractAccessExecutionGraphHandlerhandles requests that require accessing the job'sAccessExecutionGraph.classAbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters>Base class for allExecutionGraphInfobased REST handlers.classAbstractJobVertexHandler<R extends ResponseBody,M extends JobVertexMessageParameters>Base class for request handlers whose response depends on a specific job vertex (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter).classAbstractSubtaskAttemptHandler<R extends ResponseBody,M extends SubtaskAttemptMessageParameters>Base class for request handlers whose response depends on a specific attempt (defined via the "SubtaskAttemptPathParameter.KEY" of a specific subtask (defined via the "SubtaskIndexPathParameter.KEY" in a specific job vertex, (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter).classAbstractSubtaskHandler<R extends ResponseBody,M extends SubtaskMessageParameters>Base class for request handlers whose response depends on a specific subtask (defined via the "SubtaskIndexPathParameter.KEY" in a specific job vertex, (defined via the "JobVertexIdPathParameter.KEY" parameter) in a specific job, defined via (defined via the "JobIDPathParameter.KEY" parameter).classJobAccumulatorsHandlerRequest handler that returns the aggregated accumulators of a job.classJobCancellationHandlerRequest handler for the cancel and stop request.classJobClientHeartbeatHandlerReceive the heartbeat from the client.classJobConfigHandlerHandler serving the job configuration.classJobDetailsHandlerHandler returning the details for the specified job.classJobExceptionsHandlerHandler serving the job exceptions.classJobExecutionResultHandlerReturns theJobExecutionResultfor a givenJobID.classJobIdsHandlerHandler for job IDs.classJobManagerJobConfigurationHandlerHandler which serves the jobmanager's configuration of a specific job.classJobManagerJobEnvironmentHandlerHandler which serves the jobmanager's environment variables of a specific job.classJobPlanHandlerHandler serving the job execution plan.classJobResourceRequirementsHandlerRest handler for reading currentresource requirementsof a given job.classJobResourceRequirementsUpdateHandlerRest handler for updatingresource requirementsof a given job.classJobsOverviewHandlerOverview handler for jobs.classJobStatusHandlerHandler for requesting job status.classJobSubmitHandlerThis handler can be used to submit jobs to a Flink cluster.classJobVertexAccumulatorsHandlerRequest handler for the job vertex accumulators.classJobVertexBackPressureHandlerRequest handler for the job vertex back pressure.classJobVertexDetailsHandlerRequest handler for the job vertex details.classJobVertexFlameGraphHandlerRequest handler for the job vertex Flame Graph.classJobVertexTaskManagersHandlerA request handler that provides the details of a job vertex, including id, name, and the runtime and metrics of all its subtasks aggregated by TaskManager.classSubtaskCurrentAttemptDetailsHandlerRequest handler providing details about a single task execution attempt.classSubtaskExecutionAttemptAccumulatorsHandlerRequest handler for the subtask execution attempt accumulators.classSubtaskExecutionAttemptDetailsHandlerHandler of specific sub task execution attempt.classSubtasksAllAccumulatorsHandlerRequest handler for the subtasks all accumulators.classSubtasksTimesHandlerRequest handler for the subtasks times info.Methods in org.apache.flink.runtime.rest.handler.job that return AbstractRestHandler Modifier and Type Method Description static AbstractRestHandler<?,?,?,?>JobVertexFlameGraphHandler. disabledHandler(GatewayRetriever<? extends RestfulGateway> leaderRetriever, Duration timeout, Map<String,String> responseHeaders) -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.checkpoints
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.checkpoints Modifier and Type Class Description classAbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters>Base class for checkpoint related REST handler.classAbstractCheckpointStatsHandler<R extends ResponseBody,M extends JobMessageParameters>Abstract class for checkpoint handlers that will cache theCheckpointStatsSnapshotobject.classCheckpointConfigHandlerHandler which serves the checkpoint configuration.static classCheckpointHandlers.CheckpointStatusHandlerHTTP handler to query for the status of the checkpoint.static classCheckpointHandlers.CheckpointTriggerHandlerHandler for the checkpoint trigger operation.classCheckpointingStatisticsHandlerHandler which serves the checkpoint statistics.classCheckpointStatisticDetailsHandlerREST handler which returns the details for a checkpoint.classTaskCheckpointStatisticDetailsHandlerREST handler which serves checkpoint statistics for subtasks. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.coordination
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.coordination Modifier and Type Class Description classClientCoordinationHandlerHandler that receives the coordination requests from the client and returns the response from the coordinator. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.metrics
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.metrics Modifier and Type Class Description classAbstractAggregatingMetricsHandler<P extends AbstractAggregatedMetricsParameters<?>>Abstract request handler for querying aggregated metrics.classAbstractMetricsHandler<M extends MessageParameters>Request handler that returns for a given task a list of all available metrics or the values for a set of metrics.classAggregatingJobsMetricsHandlerRequest handler that returns, aggregated across jobs, a list of all available metrics or the values for a set of metrics.classAggregatingSubtasksMetricsHandlerRequest handler that returns, aggregated across subtasks, a list of all available metrics or the values for a set of metrics.classAggregatingTaskManagersMetricsHandlerRequest handler that returns, aggregated across task managers, a list of all available metrics or the values for a set of metrics.classJobManagerMetricsHandlerHandler that returns JobManager metrics.classJobManagerOperatorMetricsHandlerHandler that returns job manager operator metrics.classJobMetricsHandlerRequest handler that returns for a given job a list of all available metrics or the values for a set of metrics.classJobVertexMetricsHandlerDeprecated.This class is subsumed bySubtaskMetricsHandlerand is only kept for backwards-compatibility.classJobVertexWatermarksHandlerHandler that returns the watermarks given aJobIDandJobVertexID.classSubtaskMetricsHandlerHandler that returns subtask metrics.classTaskManagerMetricsHandlerHandler that returns TaskManager metrics. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.rescaling
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.rescaling Modifier and Type Class Description classRescalingHandlers.RescalingStatusHandlerHandler which reports the status of the rescaling operation.classRescalingHandlers.RescalingTriggerHandlerHandler which triggers the rescaling of the specified job. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.savepoints
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.job.savepoints Modifier and Type Class Description classSavepointDisposalHandlers.SavepointDisposalStatusHandlerAbstractAsynchronousOperationHandlers.StatusHandlerimplementation for the savepoint disposal operation.classSavepointDisposalHandlers.SavepointDisposalTriggerHandlerAbstractAsynchronousOperationHandlers.TriggerHandlerimplementation for the savepoint disposal operation.static classSavepointHandlers.SavepointStatusHandlerHTTP handler to query for the status of the savepoint.classSavepointHandlers.SavepointTriggerHandlerHTTP handler to trigger savepoints.classSavepointHandlers.StopWithSavepointHandlerHTTP handler to stop a job with a savepoint. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.resourcemanager
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.resourcemanager Modifier and Type Class Description classAbstractResourceManagerHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters>Base class for REST handlers which need access to theResourceManager. -
Uses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.taskmanager
Subclasses of AbstractRestHandler in org.apache.flink.runtime.rest.handler.taskmanager Modifier and Type Class Description classTaskManagerDetailsHandlerHandler which serves detailed TaskManager information.classTaskManagerLogListHandlerHandler which serves detailed TaskManager log list information.classTaskManagerProfilingHandlerRest handler which serves the profiling service from aTaskExecutor.classTaskManagerProfilingListHandlerHandler which serves detailed TaskManager profiling list information.classTaskManagersHandlerReturns an overview over all registered TaskManagers of the cluster.classTaskManagerThreadDumpHandlerRest handler which serves the thread dump info from aTaskExecutor.
-