Uses of Class
org.apache.flink.runtime.instance.SlotSharingGroupId
-
-
Uses of SlotSharingGroupId in org.apache.flink.runtime.instance
Methods in org.apache.flink.runtime.instance that return SlotSharingGroupId Modifier and Type Method Description static SlotSharingGroupId
SlotSharingGroupId. fromHexString(String hexString)
-
Uses of SlotSharingGroupId in org.apache.flink.runtime.jobmanager.scheduler
Methods in org.apache.flink.runtime.jobmanager.scheduler that return SlotSharingGroupId Modifier and Type Method Description SlotSharingGroupId
SlotSharingGroup. getSlotSharingGroupId()
-
Uses of SlotSharingGroupId in org.apache.flink.runtime.rest.messages.job
Methods in org.apache.flink.runtime.rest.messages.job that return SlotSharingGroupId Modifier and Type Method Description SlotSharingGroupId
JobDetailsInfo.JobVertexDetailsInfo. getSlotSharingGroupId()
Constructors in org.apache.flink.runtime.rest.messages.job with parameters of type SlotSharingGroupId Constructor Description JobVertexDetailsInfo(JobVertexID jobVertexID, SlotSharingGroupId slotSharingGroupId, String name, int maxParallelism, int parallelism, ExecutionState executionState, long startTime, long endTime, long duration, Map<ExecutionState,Integer> tasksPerState, IOMetricsInfo jobVertexMetrics)
-
Uses of SlotSharingGroupId in org.apache.flink.runtime.rest.messages.json
Methods in org.apache.flink.runtime.rest.messages.json that return SlotSharingGroupId Modifier and Type Method Description SlotSharingGroupId
SlotSharingGroupIDDeserializer. deserialize(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonParser p, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.DeserializationContext ctxt)
Methods in org.apache.flink.runtime.rest.messages.json with parameters of type SlotSharingGroupId Modifier and Type Method Description void
SlotSharingGroupIDSerializer. serialize(SlotSharingGroupId value, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.core.JsonGenerator gen, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.SerializerProvider provider)
-