Uses of Interface
org.apache.flink.runtime.rest.messages.ResponseBody
-
-
Uses of ResponseBody in org.apache.flink.runtime.messages.webmonitor
Classes in org.apache.flink.runtime.messages.webmonitor that implement ResponseBody Modifier and Type Class Description class
JobIdsWithStatusOverview
An overview of how many jobs are in which status.class
JobStatusInfo
The status of a specific job.class
MultipleJobsDetails
An actor messages describing details of various jobs. -
Uses of ResponseBody in org.apache.flink.runtime.rest
Methods in org.apache.flink.runtime.rest with type parameters of type ResponseBody Modifier and Type Method Description <M extends MessageHeaders<EmptyRequestBody,P,EmptyMessageParameters>,P extends ResponseBody>
CompletableFuture<P>RestClient. sendRequest(String targetAddress, int targetPort, M messageHeaders)
<M extends MessageHeaders<R,P,U>,U extends MessageParameters,R extends RequestBody,P extends ResponseBody>
CompletableFuture<P>RestClient. sendRequest(String targetAddress, int targetPort, M messageHeaders, U messageParameters, R request)
<M extends MessageHeaders<R,P,U>,U extends MessageParameters,R extends RequestBody,P extends ResponseBody>
CompletableFuture<P>RestClient. sendRequest(String targetAddress, int targetPort, M messageHeaders, U messageParameters, R request, Collection<FileUpload> fileUploads)
<M extends MessageHeaders<R,P,U>,U extends MessageParameters,R extends RequestBody,P extends ResponseBody>
CompletableFuture<P>RestClient. sendRequest(String targetAddress, int targetPort, M messageHeaders, U messageParameters, R request, Collection<FileUpload> fileUploads, RestAPIVersion<? extends RestAPIVersion<?>> apiVersion)
-
Uses of ResponseBody in org.apache.flink.runtime.rest.handler
Classes in org.apache.flink.runtime.rest.handler with type parameters of type ResponseBody 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 ResponseBody in org.apache.flink.runtime.rest.handler.async
Classes in org.apache.flink.runtime.rest.handler.async that implement ResponseBody Modifier and Type Class Description class
AsynchronousOperationResult<V>
Result of an asynchronous operation.class
TriggerResponse
Response to the triggering of an asynchronous operation. -
Uses of ResponseBody in org.apache.flink.runtime.rest.handler.job
Classes in org.apache.flink.runtime.rest.handler.job with type parameters of type ResponseBody 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). -
Uses of ResponseBody in org.apache.flink.runtime.rest.handler.job.checkpoints
Classes in org.apache.flink.runtime.rest.handler.job.checkpoints with type parameters of type ResponseBody 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. -
Uses of ResponseBody in org.apache.flink.runtime.rest.handler.legacy.messages
Classes in org.apache.flink.runtime.rest.handler.legacy.messages that implement ResponseBody Modifier and Type Class Description class
ClusterOverviewWithVersion
Cluster overview message including the current Flink version and commit id. -
Uses of ResponseBody in org.apache.flink.runtime.rest.handler.resourcemanager
Classes in org.apache.flink.runtime.rest.handler.resourcemanager with type parameters of type ResponseBody 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 ResponseBody in org.apache.flink.runtime.rest.handler.util
Methods in org.apache.flink.runtime.rest.handler.util with type parameters of type ResponseBody Modifier and Type Method Description static <P extends ResponseBody>
CompletableFuture<Void>HandlerUtils. sendResponse(org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandlerContext channelHandlerContext, org.apache.flink.shaded.netty4.io.netty.handler.codec.http.HttpRequest httpRequest, P response, org.apache.flink.shaded.netty4.io.netty.handler.codec.http.HttpResponseStatus statusCode, Map<String,String> headers)
Sends the given response and status code to the given channel. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages
Classes in org.apache.flink.runtime.rest.messages with type parameters of type ResponseBody Modifier and Type Class Description class
CustomHeadersDecorator<R extends RequestBody,P extends ResponseBody,M extends MessageParameters>
Decorator class forMessageHeaders
that adds the ability to include custom HTTP headers.interface
MessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters>
This class linksRequestBody
s toResponseBody
s types and contains meta-data required for their http headers.interface
RuntimeMessageHeaders<R extends RequestBody,P extends ResponseBody,M extends MessageParameters>
This class linksRequestBody
s toResponseBody
s types and contains meta-data required for their http headers in runtime module.Classes in org.apache.flink.runtime.rest.messages that implement ResponseBody Modifier and Type Class Description class
AggregatedTaskDetailsInfo
Aggregated info of a set of tasks.class
ConfigurationInfo
Response of theClusterConfigHandler
, represented as a list of key-value pairs of the clusterConfiguration
.class
DashboardConfiguration
Response of theDashboardConfigHandler
containing general configuration values such as the time zone and the refresh interval.class
EmptyResponseBody
EmptyResponseBody
implementation.class
EnvironmentInfo
The response of environment info.class
ErrorResponseBody
Generic response body for communicating errors on the server.class
JobAccumulatorsInfo
Response type of theJobAccumulatorsHandler
.class
JobConfigInfo
Response type of theJobConfigHandler
.class
JobExceptionsInfoWithHistory
JobExceptionsInfoWithHistory
providing a history of previously caused failures.class
JobPlanInfo
Response type of theJobPlanHandler
.class
JobVertexAccumulatorsInfo
Response type of theJobVertexAccumulatorsHandler
.class
JobVertexBackPressureInfo
Response type of theJobVertexBackPressureHandler
.class
JobVertexDetailsInfo
Response type of theJobVertexDetailsHandler
.class
JobVertexTaskManagersInfo
Response type of theJobVertexTaskManagersHandler
.class
LogListInfo
Class containing a collection ofLogInfo
.class
LogUrlResponse
Response of log URLs.class
ProfilingInfo
Contains information of a Profiling Instance.class
ProfilingInfoList
Class containing a collection ofProfilingInfo
.class
ResourceProfileInfo
Contains information of aResourceProfile
.class
SubtasksTimesInfo
Response type of theSubtasksTimesHandler
.class
ThreadDumpInfo
Class containing thread dump information. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.checkpoints
Classes in org.apache.flink.runtime.rest.messages.checkpoints that implement ResponseBody Modifier and Type Class Description class
CheckpointConfigInfo
Response class of theCheckpointConfigHandler
.class
CheckpointInfo
Represents information about a triggered checkpoint.class
CheckpointingStatistics
Response of theCheckpointingStatisticsHandler
.class
CheckpointStatistics
Statistics for a checkpoint.static class
CheckpointStatistics.CompletedCheckpointStatistics
Statistics for a completed checkpoint.static class
CheckpointStatistics.FailedCheckpointStatistics
Statistics for a failed checkpoint.static class
CheckpointStatistics.PendingCheckpointStatistics
Statistics for a pending checkpoint.class
TaskCheckpointStatistics
Checkpoint statistics for a single task.class
TaskCheckpointStatisticsWithSubtaskDetails
Task checkpoint statistics which also includes information about the sub task checkpoint statistics. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.dataset
Classes in org.apache.flink.runtime.rest.messages.dataset that implement ResponseBody Modifier and Type Class Description class
ClusterDataSetListResponseBody
-
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.job
Classes in org.apache.flink.runtime.rest.messages.job that implement ResponseBody Modifier and Type Class Description class
JobDetailsInfo
Details about a job.class
JobExecutionResultResponseBody
class
JobResourceRequirementsBody
Body for change job requests.class
JobSubmitResponseBody
Response to the submission of a job, containing a URL from which the status of the job can be retrieved from.class
SubtaskExecutionAttemptAccumulatorsInfo
Response type of theSubtaskExecutionAttemptAccumulatorsHandler
.class
SubtaskExecutionAttemptDetailsInfo
The sub task execution attempt response.class
SubtasksAllAccumulatorsInfo
Response type of theSubtasksAllAccumulatorsHandler
. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.job.coordination
Classes in org.apache.flink.runtime.rest.messages.job.coordination that implement ResponseBody Modifier and Type Class Description class
ClientCoordinationResponseBody
Response that carries a serializedCoordinationResponse
to the client. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.job.metrics
Classes in org.apache.flink.runtime.rest.messages.job.metrics that implement ResponseBody Modifier and Type Class Description class
AggregatedMetricsResponseBody
Response type for a collection of aggregated metrics.class
MetricCollectionResponseBody
Response type for a collection of metrics. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.job.savepoints
Classes in org.apache.flink.runtime.rest.messages.job.savepoints that implement ResponseBody Modifier and Type Class Description class
SavepointInfo
Represents information about a finished savepoint. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.queue
Subinterfaces of ResponseBody in org.apache.flink.runtime.rest.messages.queue Modifier and Type Interface Description interface
AsynchronouslyCreatedResource<T>
Interface for REST resources that are created asynchronously. -
Uses of ResponseBody in org.apache.flink.runtime.rest.messages.taskmanager
Classes in org.apache.flink.runtime.rest.messages.taskmanager that implement ResponseBody Modifier and Type Class Description class
SlotInfo
Class containing information for a slot ofTaskManagerSlotInformation
.class
TaskManagerDetailsInfo
Message containing base information about aTaskExecutor
and more detailed metrics.class
TaskManagerInfo
Base class containing information for aTaskExecutor
.class
TaskManagersInfo
Class containing a collection ofTaskManagerInfo
. -
Uses of ResponseBody in org.apache.flink.runtime.webmonitor.history
Constructors in org.apache.flink.runtime.webmonitor.history with parameters of type ResponseBody Constructor Description ArchivedJson(String path, ResponseBody json)
-
Uses of ResponseBody in org.apache.flink.runtime.webmonitor.threadinfo
Classes in org.apache.flink.runtime.webmonitor.threadinfo that implement ResponseBody Modifier and Type Class Description class
VertexFlameGraph
Flame Graph representation for a job vertex or an execution vertex.
-