Uses of Class
org.apache.flink.runtime.rest.messages.MessageParameter
-
-
Uses of MessageParameter in org.apache.flink.runtime.rest.messages
Subclasses of MessageParameter in org.apache.flink.runtime.rest.messages Modifier and Type Class Description class
AccumulatorsIncludeSerializedValueQueryParameter
Query parameter for job's accumulator handlerJobAccumulatorsHandler
.class
FlameGraphTypeQueryParameter
Flame Graph type query parameter.class
JobIDPathParameter
Path parameter identifying jobs.class
JobVertexIdPathParameter
Path parameter specifying aJobVertexID
.class
LogFileNamePathParameter
Parameters used byTaskManagerCustomLogHandler
andJobManagerCustomLogHandler
.class
MessagePathParameter<X>
This class represents path parameters of a request.class
MessageQueryParameter<X>
This class represents query parameters of a request.class
OperatorUidPathParameter
Path parameter identifying operators.class
ProfilingFileNamePathParameter
Parameters used byJobManagerProfilingFileHandler
.class
RescalingParallelismQueryParameter
Parallelism for the rescaling of jobs specified as aMessageQueryParameter
.class
SubtaskIndexPathParameter
Path parameter specifying the index of a subtask.class
SubtaskIndexQueryParameter
Query parameter specifying the index of a subtask.class
TerminationModeQueryParameter
Termination mode query parameter.class
TriggerIdPathParameter
MessagePathParameter
for the trigger id of an asynchronous operation. -
Uses of MessageParameter in org.apache.flink.runtime.rest.messages.checkpoints
Subclasses of MessageParameter in org.apache.flink.runtime.rest.messages.checkpoints Modifier and Type Class Description class
CheckpointIdPathParameter
Path parameter for the checkpoint id of typeLong
. -
Uses of MessageParameter in org.apache.flink.runtime.rest.messages.dataset
Subclasses of MessageParameter in org.apache.flink.runtime.rest.messages.dataset Modifier and Type Class Description class
ClusterDataSetIdPathParameter
Path parameter identifying cluster data sets. -
Uses of MessageParameter in org.apache.flink.runtime.rest.messages.job
Subclasses of MessageParameter in org.apache.flink.runtime.rest.messages.job Modifier and Type Class Description class
FailureLabelFilterParameter
Specifies a collections of failure labels, filtering the exceptions returned for JobExceptionsHandler.class
SubtaskAttemptPathParameter
Path parameter identifying subtask attempt.class
UpperLimitExceptionParameter
Specifies the upper limit of exceptions to return for JobExceptionsHandler. -
Uses of MessageParameter in org.apache.flink.runtime.rest.messages.job.metrics
Subclasses of MessageParameter in org.apache.flink.runtime.rest.messages.job.metrics Modifier and Type Class Description class
JobsFilterQueryParameter
MessageQueryParameter
for selecting jobs when aggregating metrics.class
MetricsAggregationParameter
TODO: add javadoc.class
MetricsFilterParameter
MessageQueryParameter
for filtering metrics provided byMetricStore
.class
SubtasksFilterQueryParameter
MessageQueryParameter
for selecting subtasks when aggregating metrics.class
TaskManagersFilterQueryParameter
MessageQueryParameter
for selecting task managers when aggregating metrics. -
Uses of MessageParameter in org.apache.flink.runtime.rest.messages.taskmanager
Subclasses of MessageParameter in org.apache.flink.runtime.rest.messages.taskmanager Modifier and Type Class Description class
TaskManagerIdPathParameter
TaskManager id path parameter used by TaskManager related handlers.
-