Uses of Class
org.apache.flink.autoscaler.JobAutoScalerContext
-
-
Uses of JobAutoScalerContext in org.apache.flink.autoscaler
Classes in org.apache.flink.autoscaler with type parameters of type JobAutoScalerContext Modifier and Type Interface Description interface
JobAutoScaler<KEY,Context extends JobAutoScalerContext<KEY>>
Flink Job AutoScaler.class
JobAutoScalerImpl<KEY,Context extends JobAutoScalerContext<KEY>>
The default implementation ofJobAutoScaler
.class
JobVertexScaler<KEY,Context extends JobAutoScalerContext<KEY>>
Component responsible for computing vertex parallelism based on the scaling metrics.class
NoopJobAutoscaler<KEY,Context extends JobAutoScalerContext<KEY>>
An autoscaler implementation which does nothing.class
RestApiMetricsCollector<KEY,Context extends JobAutoScalerContext<KEY>>
Metric collector using flink rest api.class
ScalingExecutor<KEY,Context extends JobAutoScalerContext<KEY>>
Class responsible for executing scaling decisions.class
ScalingMetricCollector<KEY,Context extends JobAutoScalerContext<KEY>>
Metric collector using flink rest api.Methods in org.apache.flink.autoscaler with type parameters of type JobAutoScalerContext Modifier and Type Method Description protected static <KEY,Context extends JobAutoScalerContext<KEY>>
intJobVertexScaler. scale(org.apache.flink.runtime.jobgraph.JobVertexID vertex, int currentParallelism, java.util.Collection<ShipStrategy> inputShipStrategies, int numSourcePartitions, int maxParallelism, double scaleFactor, int parallelismLowerLimit, int parallelismUpperLimit, AutoScalerEventHandler<KEY,Context> eventHandler, Context context)
Computing the newParallelism.Methods in org.apache.flink.autoscaler with parameters of type JobAutoScalerContext Modifier and Type Method Description JobDetailsInfo
ScalingMetricCollector. getJobDetailsInfo(JobAutoScalerContext<KEY> context, java.time.Duration clientTimeout)
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 JobAutoScalerContext in org.apache.flink.autoscaler.event
Classes in org.apache.flink.autoscaler.event with type parameters of type JobAutoScalerContext Modifier and Type Interface Description interface
AutoScalerEventHandler<KEY,Context extends JobAutoScalerContext<KEY>>
Handler for autoscaler events.class
LoggingEventHandler<KEY,Context extends JobAutoScalerContext<KEY>>
Autoscaler event handler which logs events. -
Uses of JobAutoScalerContext in org.apache.flink.autoscaler.jdbc.event
Classes in org.apache.flink.autoscaler.jdbc.event with type parameters of type JobAutoScalerContext Modifier and Type Class Description class
JdbcAutoScalerEventHandler<KEY,Context extends JobAutoScalerContext<KEY>>
The event handler which persists its event in JDBC related database. -
Uses of JobAutoScalerContext in org.apache.flink.autoscaler.jdbc.state
Classes in org.apache.flink.autoscaler.jdbc.state with type parameters of type JobAutoScalerContext 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 JobAutoScalerContext in org.apache.flink.autoscaler.metrics
Methods in org.apache.flink.autoscaler.metrics with type parameters of type JobAutoScalerContext 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 JobAutoScalerContext in org.apache.flink.autoscaler.realizer
Classes in org.apache.flink.autoscaler.realizer with type parameters of type JobAutoScalerContext Modifier and Type Interface Description interface
ScalingRealizer<KEY,Context extends JobAutoScalerContext<KEY>>
The Scaling Realizer is responsible for applying scaling actions, i.e. -
Uses of JobAutoScalerContext in org.apache.flink.autoscaler.standalone
Classes in org.apache.flink.autoscaler.standalone with type parameters of type JobAutoScalerContext Modifier and Type Interface Description interface
JobListFetcher<KEY,Context extends JobAutoScalerContext<KEY>>
The JobListFetcher will fetch the jobContext of all jobs.class
StandaloneAutoscalerExecutor<KEY,Context extends JobAutoScalerContext<KEY>>
The executor of the standalone autoscaler.Methods in org.apache.flink.autoscaler.standalone with type parameters of type JobAutoScalerContext Modifier and Type Method Description static <KEY,Context extends JobAutoScalerContext<KEY>>
AutoScalerEventHandler<KEY,Context>AutoscalerEventHandlerFactory. create(org.apache.flink.configuration.Configuration conf)
static <KEY,Context extends JobAutoScalerContext<KEY>>
AutoScalerStateStore<KEY,Context>AutoscalerStateStoreFactory. create(org.apache.flink.configuration.Configuration conf)
static <KEY,Context extends JobAutoScalerContext<KEY>>
voidStandaloneAutoscalerEntrypoint. main(java.lang.String[] args)
-
Uses of JobAutoScalerContext in org.apache.flink.autoscaler.standalone.flinkcluster
Methods in org.apache.flink.autoscaler.standalone.flinkcluster that return types with arguments of type JobAutoScalerContext Modifier and Type Method Description java.util.Collection<JobAutoScalerContext<org.apache.flink.api.common.JobID>>
FlinkClusterJobListFetcher. fetch(org.apache.flink.configuration.Configuration baseConf)
-
Uses of JobAutoScalerContext in org.apache.flink.autoscaler.standalone.realizer
Classes in org.apache.flink.autoscaler.standalone.realizer with type parameters of type JobAutoScalerContext Modifier and Type Class Description class
RescaleApiScalingRealizer<KEY,Context extends JobAutoScalerContext<KEY>>
A ScalingRealizer which uses the Rescale API to apply parallelism changes. -
Uses of JobAutoScalerContext in org.apache.flink.autoscaler.state
Classes in org.apache.flink.autoscaler.state with type parameters of type JobAutoScalerContext Modifier and Type Interface Description interface
AutoScalerStateStore<KEY,Context extends JobAutoScalerContext<KEY>>
The state store is responsible for storing all state during scaling.class
InMemoryAutoScalerStateStore<KEY,Context extends JobAutoScalerContext<KEY>>
State store based on the Java Heap, the state will be discarded after process restarts. -
Uses of JobAutoScalerContext in org.apache.flink.autoscaler.tuning
Methods in org.apache.flink.autoscaler.tuning with parameters of type JobAutoScalerContext 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 org.apache.flink.configuration.MemorySize
MemoryTuning. getTotalMemory(org.apache.flink.configuration.Configuration config, JobAutoScalerContext<?> ctx)
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 JobAutoScalerContext in org.apache.flink.kubernetes.operator.autoscaler
Subclasses of JobAutoScalerContext in org.apache.flink.kubernetes.operator.autoscaler Modifier and Type Class Description class
KubernetesJobAutoScalerContext
An implementation of JobAutoscalerContext for Kubernetes.
-