Modifier and Type | Class and Description |
---|---|
class |
AbstractRestHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters>
Super class for netty-based handlers that work with
RequestBody s and ResponseBody s. |
Modifier and Type | Class and 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.
|
Modifier and Type | Class and 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 |
JobManagerLogFileHandler
Rest handler which serves the log files from JobManager.
|
class |
JobManagerLogListHandler
Handler which serves detailed JobManager log list information.
|
class |
ShutdownHandler
REST handler which allows to shut down the cluster.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterDataSetDeleteHandlers.ClusterDataSetDeleteStatusHandler
StatusHandler implementation for the cluster data set delete operation. |
class |
ClusterDataSetDeleteHandlers.ClusterDataSetDeleteTriggerHandler
TriggerHandler implementation for the cluster data set delete operation. |
class |
ClusterDataSetListHandler
Handler for
ClusterDataSetListHeaders . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractExecutionGraphHandler<R extends ResponseBody,M extends JobMessageParameters>
Base class for all
AccessExecutionGraph 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 |
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 the
JobExecutionResult for a given JobID . |
class |
JobIdsHandler
Handler for job IDs.
|
class |
JobPlanHandler
Handler serving the job execution plan.
|
class |
JobsOverviewHandler
Overview handler for jobs.
|
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 |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractCheckpointHandler<R extends ResponseBody,M extends CheckpointMessageParameters>
Base class for checkpoint related REST handler.
|
class |
CheckpointConfigHandler
Handler which serves the checkpoint configuration.
|
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.
|
Modifier and Type | Class and Description |
---|---|
class |
ClientCoordinationHandler
Handler that receives the coordination requests from the client and returns the response from the
coordinator.
|
Modifier and Type | Class and 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 |
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 by
SubtaskMetricsHandler and is only kept for
backwards-compatibility. |
class |
JobVertexWatermarksHandler
Handler that returns the watermarks given a
JobID and JobVertexID . |
class |
SubtaskMetricsHandler
Handler that returns subtask metrics.
|
class |
TaskManagerMetricsHandler
Handler that returns TaskManager metrics.
|
Modifier and Type | Class and 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.
|
Modifier and Type | Class and Description |
---|---|
class |
SavepointDisposalHandlers.SavepointDisposalStatusHandler
StatusHandler implementation for the savepoint disposal operation. |
class |
SavepointDisposalHandlers.SavepointDisposalTriggerHandler
TriggerHandler implementation for the savepoint disposal operation. |
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.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractResourceManagerHandler<T extends RestfulGateway,R extends RequestBody,P extends ResponseBody,M extends MessageParameters>
Base class for REST handlers which need access to the
ResourceManager . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTaskManagerFileHandler<M extends TaskManagerMessageParameters>
Base class for serving files from the
TaskExecutor . |
class |
TaskManagerCustomLogHandler
Rest handler which serves the custom file of the
TaskExecutor . |
class |
TaskManagerDetailsHandler
Handler which serves detailed TaskManager information.
|
class |
TaskManagerLogFileHandler
Rest handler which serves the log files from
TaskExecutor . |
class |
TaskManagerLogListHandler
Handler which serves detailed TaskManager log list information.
|
class |
TaskManagersHandler
Returns an overview over all registered TaskManagers of the cluster.
|
class |
TaskManagerStdoutFileHandler
Rest handler which serves the stdout file of the
TaskExecutor . |
class |
TaskManagerThreadDumpHandler
Rest handler which serves the thread dump info from a
TaskExecutor . |
Modifier and Type | Class and Description |
---|---|
class |
JarDeleteHandler
Handles requests for deletion of jars.
|
class |
JarListHandler
Handle request for listing uploaded jars.
|
class |
JarPlanHandler
This handler handles requests to fetch the plan for a jar.
|
class |
JarRunHandler
Handler to submit jobs uploaded via the Web UI.
|
class |
JarUploadHandler
Handles .jar file uploads.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.