Uses of Class
org.apache.flink.runtime.rest.handler.AbstractHandler
-
-
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler Modifier and Type Class Description 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. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.async
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.async 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 AbstractHandler in org.apache.flink.runtime.rest.handler.cluster
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.cluster Modifier and Type Class Description class
AbstractJobManagerFileHandler<M extends MessageParameters>
Base class for serving files from the JobManager.class
ClusterConfigHandler
Handler which serves the cluster's configuration.class
ClusterOverviewHandler
Handler which returns the cluster overview information with version.class
DashboardConfigHandler
Handler which returns the dashboard configuration.class
JobManagerCustomLogHandler
Rest handler which serves the custom log file from JobManager.class
JobManagerEnvironmentHandler
Handler which serves the jobmanager's environment variables.class
JobManagerLogFileHandler
Rest handler which serves the log files from JobManager.class
JobManagerLogListHandler
Handler which serves detailed JobManager log list information.class
JobManagerProfilingFileHandler
Rest handler which serves the profiler result file from JobManager.class
JobManagerProfilingHandler
Rest handler which serves the profiling info from the JobManager.class
JobManagerProfilingListHandler
Rest handler which serves the profiling list from the JobManager.class
JobManagerThreadDumpHandler
Rest handler which serves the thread dump info from the JobManager.class
ShutdownHandler
REST handler which allows to shut down the cluster. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.dataset
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.dataset Modifier and Type Class Description class
ClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandler
AbstractAsynchronousOperationHandlers.StatusHandler
implementation for the cluster data set delete operation.class
ClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandler
AbstractAsynchronousOperationHandlers.TriggerHandler
implementation for the cluster data set delete operation.class
ClusterDataSetListHandler
Handler forClusterDataSetListHeaders
. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.job
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.job Modifier and Type Class Description class
AbstractAccessExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters>
AbstractAccessExecutionGraphHandler
handles requests that require accessing the job'sAccessExecutionGraph
.class
AbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters>
Base class for allExecutionGraphInfo
based REST handlers.class
AbstractJobVertexHandler<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).class
AbstractSubtaskAttemptHandler<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).class
AbstractSubtaskHandler<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).class
JobAccumulatorsHandler
Request handler that returns the aggregated accumulators of a job.class
JobCancellationHandler
Request handler for the cancel and stop request.class
JobClientHeartbeatHandler
Receive the heartbeat from the client.class
JobConfigHandler
Handler serving the job configuration.class
JobDetailsHandler
Handler returning the details for the specified job.class
JobExceptionsHandler
Handler serving the job exceptions.class
JobExecutionResultHandler
Returns theJobExecutionResult
for a givenJobID
.class
JobIdsHandler
Handler for job IDs.class
JobManagerJobConfigurationHandler
Handler which serves the jobmanager's configuration of a specific job.class
JobManagerJobEnvironmentHandler
Handler which serves the jobmanager's environment variables of a specific job.class
JobPlanHandler
Handler serving the job execution plan.class
JobResourceRequirementsHandler
Rest handler for reading currentresource requirements
of a given job.class
JobResourceRequirementsUpdateHandler
Rest handler for updatingresource requirements
of a given job.class
JobsOverviewHandler
Overview handler for jobs.class
JobStatusHandler
Handler for requesting job status.class
JobSubmitHandler
This handler can be used to submit jobs to a Flink cluster.class
JobVertexAccumulatorsHandler
Request handler for the job vertex accumulators.class
JobVertexBackPressureHandler
Request handler for the job vertex back pressure.class
JobVertexDetailsHandler
Request handler for the job vertex details.class
JobVertexFlameGraphHandler
Request handler for the job vertex Flame Graph.class
JobVertexTaskManagersHandler
A 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.class
SubtaskCurrentAttemptDetailsHandler
Request handler providing details about a single task execution attempt.class
SubtaskExecutionAttemptAccumulatorsHandler
Request handler for the subtask execution attempt accumulators.class
SubtaskExecutionAttemptDetailsHandler
Handler of specific sub task execution attempt.class
SubtasksAllAccumulatorsHandler
Request handler for the subtasks all accumulators.class
SubtasksTimesHandler
Request handler for the subtasks times info. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.checkpoints
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.checkpoints Modifier and Type Class Description class
AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters>
Base class for checkpoint related REST handler.class
AbstractCheckpointStatsHandler<R extends ResponseBody,M extends JobMessageParameters>
Abstract class for checkpoint handlers that will cache theCheckpointStatsSnapshot
object.class
CheckpointConfigHandler
Handler which serves the checkpoint configuration.static class
CheckpointHandlers.CheckpointStatusHandler
HTTP handler to query for the status of the checkpoint.static class
CheckpointHandlers.CheckpointTriggerHandler
Handler for the checkpoint trigger operation.class
CheckpointingStatisticsHandler
Handler which serves the checkpoint statistics.class
CheckpointStatisticDetailsHandler
REST handler which returns the details for a checkpoint.class
TaskCheckpointStatisticDetailsHandler
REST handler which serves checkpoint statistics for subtasks. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.coordination
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.coordination Modifier and Type Class Description class
ClientCoordinationHandler
Handler that receives the coordination requests from the client and returns the response from the coordinator. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.metrics
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.metrics Modifier and Type Class Description class
AbstractAggregatingMetricsHandler<P extends AbstractAggregatedMetricsParameters<?>>
Abstract request handler for querying aggregated metrics.class
AbstractMetricsHandler<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.class
AggregatingJobsMetricsHandler
Request handler that returns, aggregated across jobs, a list of all available metrics or the values for a set of metrics.class
AggregatingSubtasksMetricsHandler
Request handler that returns, aggregated across subtasks, a list of all available metrics or the values for a set of metrics.class
AggregatingTaskManagersMetricsHandler
Request handler that returns, aggregated across task managers, a list of all available metrics or the values for a set of metrics.class
JobManagerMetricsHandler
Handler that returns JobManager metrics.class
JobManagerOperatorMetricsHandler
Handler that returns job manager operator metrics.class
JobMetricsHandler
Request handler that returns for a given job a list of all available metrics or the values for a set of metrics.class
JobVertexMetricsHandler
Deprecated.This class is subsumed bySubtaskMetricsHandler
and is only kept for backwards-compatibility.class
JobVertexWatermarksHandler
Handler that returns the watermarks given aJobID
andJobVertexID
.class
SubtaskMetricsHandler
Handler that returns subtask metrics.class
TaskManagerMetricsHandler
Handler that returns TaskManager metrics. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.rescaling
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.rescaling Modifier and Type Class Description class
RescalingHandlers.RescalingStatusHandler
Handler which reports the status of the rescaling operation.class
RescalingHandlers.RescalingTriggerHandler
Handler which triggers the rescaling of the specified job. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.savepoints
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.job.savepoints Modifier and Type Class Description class
SavepointDisposalHandlers.SavepointDisposalStatusHandler
AbstractAsynchronousOperationHandlers.StatusHandler
implementation for the savepoint disposal operation.class
SavepointDisposalHandlers.SavepointDisposalTriggerHandler
AbstractAsynchronousOperationHandlers.TriggerHandler
implementation for the savepoint disposal operation.static class
SavepointHandlers.SavepointStatusHandler
HTTP handler to query for the status of the savepoint.class
SavepointHandlers.SavepointTriggerHandler
HTTP handler to trigger savepoints.class
SavepointHandlers.StopWithSavepointHandler
HTTP handler to stop a job with a savepoint. -
Uses of AbstractHandler in org.apache.flink.runtime.rest.handler.resourcemanager
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.resourcemanager 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 AbstractHandler in org.apache.flink.runtime.rest.handler.taskmanager
Subclasses of AbstractHandler in org.apache.flink.runtime.rest.handler.taskmanager Modifier and Type Class Description class
AbstractTaskManagerFileHandler<M extends TaskManagerMessageParameters>
Base class for serving files from theTaskExecutor
.class
TaskManagerCustomLogHandler
Rest handler which serves the custom file of theTaskExecutor
.class
TaskManagerDetailsHandler
Handler which serves detailed TaskManager information.class
TaskManagerLogFileHandler
Rest handler which serves the log files fromTaskExecutor
.class
TaskManagerLogListHandler
Handler which serves detailed TaskManager log list information.class
TaskManagerProfilingFileHandler
Rest handler which serves the profiling result file of theTaskExecutor
.class
TaskManagerProfilingHandler
Rest handler which serves the profiling service from aTaskExecutor
.class
TaskManagerProfilingListHandler
Handler which serves detailed TaskManager profiling list information.class
TaskManagersHandler
Returns an overview over all registered TaskManagers of the cluster.class
TaskManagerStdoutFileHandler
Rest handler which serves the stdout file of theTaskExecutor
.class
TaskManagerThreadDumpHandler
Rest handler which serves the thread dump info from aTaskExecutor
.
-