Uses of Class
org.apache.flink.autoscaler.ScalingSummary
-
-
Uses of ScalingSummary in org.apache.flink.autoscaler
Method parameters in org.apache.flink.autoscaler with type arguments of type ScalingSummary Modifier and Type Method Description JobVertexScaler.ParallelismChange
JobVertexScaler. computeScaleTargetParallelism(Context context, org.apache.flink.runtime.jobgraph.JobVertexID vertex, java.util.Collection<ShipStrategy> inputShipStrategies, java.util.Map<ScalingMetric,EvaluatedScalingMetric> evaluatedMetrics, java.util.SortedMap<java.time.Instant,ScalingSummary> history, java.time.Duration restartTime, DelayedScaleDown delayedScaleDown)
boolean
ScalingTracking. recordRestartDurationIfTrackedAndParallelismMatches(java.time.Instant jobRunningTs, JobTopology jobTopology, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
Sets restart duration for the latest scaling record if its parallelism matches the current job parallelism.boolean
ScalingExecutor. scaleResource(Context context, EvaluatedMetrics evaluatedMetrics, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory, ScalingTracking scalingTracking, java.time.Instant now, JobTopology jobTopology, DelayedScaleDown delayedScaleDown)
protected boolean
ScalingExecutor. scalingWouldExceedMaxResources(org.apache.flink.configuration.Configuration tunedConfig, JobTopology jobTopology, EvaluatedMetrics evaluatedMetrics, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, Context ctx)
protected static boolean
ScalingExecutor. scalingWouldExceedResourceQuota(org.apache.flink.configuration.Configuration tunedConfig, JobTopology jobTopology, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, JobAutoScalerContext<?> ctx)
-
Uses of ScalingSummary in org.apache.flink.autoscaler.event
Method parameters in org.apache.flink.autoscaler.event with type arguments of type ScalingSummary Modifier and Type Method Description static java.lang.String
AutoScalerEventHandler. getParallelismHashCode(java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaryHashMap)
default void
AutoScalerEventHandler. handleScalingEvent(Context context, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, java.lang.String message, java.time.Duration interval)
Handle scaling reports.static java.lang.String
AutoScalerEventHandler. scalingReport(java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, java.lang.String message)
-
Uses of ScalingSummary in org.apache.flink.autoscaler.jdbc.event
Method parameters in org.apache.flink.autoscaler.jdbc.event with type arguments of type ScalingSummary Modifier and Type Method Description void
JdbcAutoScalerEventHandler. handleScalingEvent(Context context, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, java.lang.String message, java.time.Duration interval)
-
Uses of ScalingSummary in org.apache.flink.autoscaler.jdbc.state
Methods in org.apache.flink.autoscaler.jdbc.state that return types with arguments of type ScalingSummary Modifier and Type Method Description java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>>
JdbcAutoScalerStateStore. getScalingHistory(Context jobContext)
Method parameters in org.apache.flink.autoscaler.jdbc.state with type arguments of type ScalingSummary Modifier and Type Method Description protected static java.lang.String
JdbcAutoScalerStateStore. serializeScalingHistory(java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
void
JdbcAutoScalerStateStore. storeScalingHistory(Context jobContext, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
-
Uses of ScalingSummary in org.apache.flink.autoscaler.metrics
Methods in org.apache.flink.autoscaler.metrics that return types with arguments of type ScalingSummary Modifier and Type Method Description static <KEY,Context extends JobAutoScalerContext<KEY>>
java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>>ScalingHistoryUtils. getTrimmedScalingHistory(AutoScalerStateStore<KEY,Context> autoScalerStateStore, Context context, java.time.Instant now)
static java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>>
ScalingHistoryUtils. trimScalingHistory(java.time.Instant now, org.apache.flink.configuration.Configuration conf, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
Method parameters in org.apache.flink.autoscaler.metrics with type arguments of type ScalingSummary Modifier and Type Method Description static <KEY,Context extends JobAutoScalerContext<KEY>>
voidScalingHistoryUtils. addToScalingHistoryAndStore(AutoScalerStateStore<KEY,Context> stateStore, Context context, java.time.Instant now, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> summaries)
static <KEY,Context extends JobAutoScalerContext<KEY>>
voidScalingHistoryUtils. addToScalingHistoryAndStore(AutoScalerStateStore<KEY,Context> stateStore, Context context, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory, java.time.Instant now, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> summaries)
static java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>>
ScalingHistoryUtils. trimScalingHistory(java.time.Instant now, org.apache.flink.configuration.Configuration conf, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
-
Uses of ScalingSummary in org.apache.flink.autoscaler.state
Methods in org.apache.flink.autoscaler.state that return types with arguments of type ScalingSummary Modifier and Type Method Description java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>>
AutoScalerStateStore. getScalingHistory(Context jobContext)
java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>>
InMemoryAutoScalerStateStore. getScalingHistory(Context jobContext)
Method parameters in org.apache.flink.autoscaler.state with type arguments of type ScalingSummary Modifier and Type Method Description void
AutoScalerStateStore. storeScalingHistory(Context jobContext, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
void
InMemoryAutoScalerStateStore. storeScalingHistory(Context jobContext, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
-
Uses of ScalingSummary in org.apache.flink.autoscaler.tuning
Method parameters in org.apache.flink.autoscaler.tuning with type arguments of type ScalingSummary Modifier and Type Method Description static org.apache.flink.configuration.MemorySize
MemoryScaling. applyMemoryScaling(org.apache.flink.configuration.MemorySize currentMemorySize, MemoryBudget memoryBudget, JobAutoScalerContext<?> context, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, EvaluatedMetrics evaluatedMetrics)
Scales the amount of memory per TaskManager proportionally to the number of TaskManagers removed/added.static ConfigChanges
MemoryTuning. tuneTaskManagerMemory(JobAutoScalerContext<?> context, EvaluatedMetrics evaluatedMetrics, JobTopology jobTopology, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, AutoScalerEventHandler eventHandler)
Emits a Configuration which contains overrides for the current configuration. -
Uses of ScalingSummary in org.apache.flink.autoscaler.utils
Method parameters in org.apache.flink.autoscaler.utils with type arguments of type ScalingSummary Modifier and Type Method Description static java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.lang.Integer>
ResourceCheckUtils. computeNewParallelisms(java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.Map<ScalingMetric,EvaluatedScalingMetric>> vertexMetrics)
-
Uses of ScalingSummary in org.apache.flink.kubernetes.operator.autoscaler
Method parameters in org.apache.flink.kubernetes.operator.autoscaler with type arguments of type ScalingSummary Modifier and Type Method Description void
KubernetesAutoScalerEventHandler. handleScalingEvent(KubernetesJobAutoScalerContext context, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,ScalingSummary> scalingSummaries, java.lang.String message, java.time.Duration interval)
-
Uses of ScalingSummary in org.apache.flink.kubernetes.operator.autoscaler.state
Methods in org.apache.flink.kubernetes.operator.autoscaler.state that return types with arguments of type ScalingSummary Modifier and Type Method Description java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>>
KubernetesAutoScalerStateStore. getScalingHistory(KubernetesJobAutoScalerContext jobContext)
Method parameters in org.apache.flink.kubernetes.operator.autoscaler.state with type arguments of type ScalingSummary Modifier and Type Method Description protected static java.lang.String
KubernetesAutoScalerStateStore. serializeScalingHistory(java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
void
KubernetesAutoScalerStateStore. storeScalingHistory(KubernetesJobAutoScalerContext jobContext, java.util.Map<org.apache.flink.runtime.jobgraph.JobVertexID,java.util.SortedMap<java.time.Instant,ScalingSummary>> scalingHistory)
-