Uses of Interface
org.apache.flink.autoscaler.state.AutoScalerStateStore
-
-
Uses of AutoScalerStateStore in org.apache.flink.autoscaler
Methods in org.apache.flink.autoscaler with parameters of type AutoScalerStateStore Modifier and Type Method Description protected JobTopology
ScalingMetricCollector. getJobTopology(Context ctx, AutoScalerStateStore<KEY,Context> stateStore, JobDetailsInfo jobDetailsInfo)
CollectedMetricHistory
ScalingMetricCollector. updateMetrics(Context ctx, AutoScalerStateStore<KEY,Context> stateStore)
Constructors in org.apache.flink.autoscaler with parameters of type AutoScalerStateStore Constructor Description JobAutoScalerImpl(ScalingMetricCollector<KEY,Context> metricsCollector, ScalingMetricEvaluator evaluator, ScalingExecutor<KEY,Context> scalingExecutor, AutoScalerEventHandler<KEY,Context> eventHandler, ScalingRealizer<KEY,Context> scalingRealizer, AutoScalerStateStore<KEY,Context> stateStore)
ScalingExecutor(AutoScalerEventHandler<KEY,Context> autoScalerEventHandler, AutoScalerStateStore<KEY,Context> autoScalerStateStore)
ScalingExecutor(AutoScalerEventHandler<KEY,Context> autoScalerEventHandler, AutoScalerStateStore<KEY,Context> autoScalerStateStore, ResourceCheck resourceCheck)
-
Uses of AutoScalerStateStore in org.apache.flink.autoscaler.jdbc.state
Classes in org.apache.flink.autoscaler.jdbc.state that implement AutoScalerStateStore Modifier and Type Class Description class
JdbcAutoScalerStateStore<KEY,Context extends JobAutoScalerContext<KEY>>
The state store which persists its state in JDBC related database. -
Uses of AutoScalerStateStore in org.apache.flink.autoscaler.metrics
Methods in org.apache.flink.autoscaler.metrics with parameters of type AutoScalerStateStore 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 <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 <KEY,Context extends JobAutoScalerContext<KEY>>
ScalingTrackingScalingHistoryUtils. getTrimmedScalingTracking(AutoScalerStateStore<KEY,Context> autoScalerStateStore, Context context, java.time.Instant now)
static <KEY,Context extends JobAutoScalerContext<KEY>>
voidScalingHistoryUtils. updateVertexList(AutoScalerStateStore<KEY,Context> stateStore, Context ctx, java.time.Instant now, java.util.Set<org.apache.flink.runtime.jobgraph.JobVertexID> vertexSet)
-
Uses of AutoScalerStateStore in org.apache.flink.autoscaler.standalone
Methods in org.apache.flink.autoscaler.standalone that return AutoScalerStateStore Modifier and Type Method Description static <KEY,Context extends JobAutoScalerContext<KEY>>
AutoScalerStateStore<KEY,Context>AutoscalerStateStoreFactory. create(org.apache.flink.configuration.Configuration conf)
-
Uses of AutoScalerStateStore in org.apache.flink.autoscaler.state
Classes in org.apache.flink.autoscaler.state that implement AutoScalerStateStore Modifier and Type Class Description class
InMemoryAutoScalerStateStore<KEY,Context extends JobAutoScalerContext<KEY>>
State store based on the Java Heap, the state will be discarded after process restarts. -
Uses of AutoScalerStateStore in org.apache.flink.kubernetes.operator.autoscaler.state
Classes in org.apache.flink.kubernetes.operator.autoscaler.state that implement AutoScalerStateStore Modifier and Type Class Description class
KubernetesAutoScalerStateStore
An AutoscalerStateStore which persists its state in Kubernetes ConfigMaps.
-