A B C D E F G H I J K L M N O P Q R S T U V W Y
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- ABANDONED - org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus.State
-
Snapshot abandoned due to job failure/upgrade.
- ABANDONED - org.apache.flink.kubernetes.operator.utils.SnapshotStatus
-
Manual snapshot is abandoned after defined retries.
- abandonSnapshotIfJobNotRunning(KubernetesClient, FlinkStateSnapshot, AbstractFlinkResource<?, ?>, EventRecorder) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Abandons a FlinkStateSnapshot resource if the referenced job is not found or not running.
- AbstractFlinkDeploymentObserver - Class in org.apache.flink.kubernetes.operator.observer.deployment
-
Base observer for session and application clusters.
- AbstractFlinkDeploymentObserver(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- AbstractFlinkResource<SPEC extends AbstractFlinkSpec,STATUS extends CommonStatus<SPEC>> - Class in org.apache.flink.kubernetes.operator.api
-
Abstract base class Flink resources.
- AbstractFlinkResource() - Constructor for class org.apache.flink.kubernetes.operator.api.AbstractFlinkResource
- AbstractFlinkResourceObserver<CR extends AbstractFlinkResource<?,?>> - Class in org.apache.flink.kubernetes.operator.observer
-
Base observer for all Flink resources.
- AbstractFlinkResourceObserver(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.AbstractFlinkResourceObserver
- AbstractFlinkResourceReconciler<CR extends AbstractFlinkResource<SPEC,STATUS>,SPEC extends AbstractFlinkSpec,STATUS extends CommonStatus<SPEC>> - Class in org.apache.flink.kubernetes.operator.reconciler.deployment
-
Base class for all Flink resource reconcilers.
- AbstractFlinkResourceReconciler(EventRecorder, StatusRecorder<CR, STATUS>, JobAutoScaler<ResourceID, KubernetesJobAutoScalerContext>) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- AbstractFlinkService - Class in org.apache.flink.kubernetes.operator.service
-
An abstract
FlinkService
containing some common implementations for the native and standalone Flink Services. - AbstractFlinkService(KubernetesClient, ArtifactManager, ExecutorService, FlinkOperatorConfiguration) - Constructor for class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- AbstractFlinkSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
The common spec.
- AbstractFlinkSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.AbstractFlinkSpec
- AbstractJobReconciler<CR extends AbstractFlinkResource<SPEC,STATUS>,SPEC extends AbstractFlinkSpec,STATUS extends CommonStatus<SPEC>> - Class in org.apache.flink.kubernetes.operator.reconciler.deployment
-
Reconciler responsible for handling the job lifecycle according to the desired and current states.
- AbstractJobReconciler(EventRecorder, StatusRecorder<CR, STATUS>, JobAutoScaler<ResourceID, KubernetesJobAutoScalerContext>) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- AbstractJobReconciler.JobUpgrade - Class in org.apache.flink.kubernetes.operator.reconciler.deployment
-
Object to capture available upgrade mode.
- ACCUMULATED_BUSY_TIME - org.apache.flink.autoscaler.metrics.ScalingMetric
- addOverride(String, String) - Method in class org.apache.flink.autoscaler.tuning.ConfigChanges
- addOverride(ConfigOption<T>, T) - Method in class org.apache.flink.autoscaler.tuning.ConfigChanges
- addRemoval(ConfigOption<?>) - Method in class org.apache.flink.autoscaler.tuning.ConfigChanges
- addScalingRecord(Instant, ScalingRecord) - Method in class org.apache.flink.autoscaler.ScalingTracking
- addStartupProbe(PodTemplateSpec) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- addToScalingHistoryAndStore(AutoScalerStateStore<KEY, Context>, Context, Instant, Map<JobVertexID, ScalingSummary>) - Static method in class org.apache.flink.autoscaler.metrics.ScalingHistoryUtils
- addToScalingHistoryAndStore(AutoScalerStateStore<KEY, Context>, Context, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>, Instant, Map<JobVertexID, ScalingSummary>) - Static method in class org.apache.flink.autoscaler.metrics.ScalingHistoryUtils
- AdmissionHandler - Class in org.apache.flink.kubernetes.operator.admission
-
Rest endpoint for validation requests.
- AdmissionHandler(Validator<HasMetadata>, Mutator<HasMetadata>) - Constructor for class org.apache.flink.kubernetes.operator.admission.AdmissionHandler
- admissionResponseFromMutation(KubernetesResource, KubernetesResource) - Static method in class org.apache.flink.kubernetes.operator.admission.mutator.DefaultRequestMutator
- after(HttpRequest, HttpResponse<?>, AsyncBody.Consumer<List<ByteBuffer>>) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- afterConnectionFailure(HttpRequest, Throwable) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- afterFailure(BasicBuilder, HttpResponse<?>, Interceptor.RequestTags) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- AggregatedMetric - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
TODO : It can be removed after upgrading flink dependency to 1.20.
- AggregatedMetric(String) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- AggregatedMetric(String, Double, Double, Double, Double, Double) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- allCanariesHealthy() - Method in class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- API_GROUP - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- API_VERSION - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- append(String, DiffResult<?>) - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.DiffBuilder
- append(String, Object[], Object[], DiffType) - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.DiffBuilder
- append(String, Object, Object, DiffType) - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.DiffBuilder
- append(String, S, S, BiFunction<S, S, Boolean>, DiffType) - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.DiffBuilder
- APPLICATION - org.apache.flink.kubernetes.operator.config.Mode
- APPLICATION - org.apache.flink.kubernetes.operator.standalone.StandaloneKubernetesConfigOptionsInternal.ClusterMode
- APPLICATION_MODE_ARG - Static variable in class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneJobManagerDecorator
- ApplicationObserver - Class in org.apache.flink.kubernetes.operator.observer.deployment
-
The observer of
Mode.APPLICATION
cluster. - ApplicationObserver(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.deployment.ApplicationObserver
- applicationProtocolNegotiator() - Method in class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- ApplicationReconciler - Class in org.apache.flink.kubernetes.operator.reconciler.deployment
-
Reconciler Flink Application deployments.
- ApplicationReconciler(EventRecorder, StatusRecorder<FlinkDeployment, FlinkDeploymentStatus>, JobAutoScaler<ResourceID, KubernetesJobAutoScalerContext>) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.deployment.ApplicationReconciler
- applyFlinkConfiguration() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyImage() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyImagePullPolicy() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyJobConfig(String, Configuration, JobSpec) - Static method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyJobManagerSpec() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyJobOrSessionSpec() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyLogConfiguration() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyMemoryScaling(MemorySize, MemoryBudget, JobAutoScalerContext<?>, Map<JobVertexID, ScalingSummary>, EvaluatedMetrics) - Static method in class org.apache.flink.autoscaler.tuning.MemoryScaling
-
Scales the amount of memory per TaskManager proportionally to the number of TaskManagers removed/added.
- applyParallelismOverrides(Context) - Method in class org.apache.flink.autoscaler.JobAutoScalerImpl
-
If there are any parallelism overrides by the
JobAutoScaler
apply them to the scalingRealizer. - applyPodTemplate() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyResourceToPodTemplate(PodTemplateSpec, Resource) - Static method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyServiceAccount() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyTaskManagerSpec() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- applyValidationErrorAndResetSpec(FlinkResourceContext<? extends AbstractFlinkResource<SPEC, ?>>, String) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
In case of validation errors we need to (temporarily) reset the old spec so that we can reconcile other outstanding changes, instead of simply blocking.
- ArtifactFetcher - Interface in org.apache.flink.kubernetes.operator.artifact
-
The artifact fetcher.
- artifactManager - Variable in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- ArtifactManager - Class in org.apache.flink.kubernetes.operator.artifact
-
Manage the user artifacts.
- ArtifactManager(FlinkConfigManager) - Constructor for class org.apache.flink.kubernetes.operator.artifact.ArtifactManager
- atLeastOneCheckpoint(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- atLeastOneCheckpoint(Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- AuditUtils - Class in org.apache.flink.kubernetes.operator.listener
-
Responsible for logging resource event/status updates.
- AuditUtils() - Constructor for class org.apache.flink.kubernetes.operator.listener.AuditUtils
- autoscaler - Variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- AUTOSCALER_CONF_PREFIX - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- AUTOSCALER_ENABLED - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- AUTOSCALER_ERROR - Static variable in class org.apache.flink.autoscaler.JobAutoScalerImpl
- AUTOSCALER_ERROR - Static variable in class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerExecutor
- AutoscalerError - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- AutoScalerEvent - Class in org.apache.flink.autoscaler.jdbc.event
-
The Jdbc autoscaler event.
- AutoScalerEvent() - Constructor for class org.apache.flink.autoscaler.jdbc.event.AutoScalerEvent
- AutoScalerEventHandler<KEY,Context extends JobAutoScalerContext<KEY>> - Interface in org.apache.flink.autoscaler.event
-
Handler for autoscaler events.
- AutoScalerEventHandler.Type - Enum in org.apache.flink.autoscaler.event
-
The type of the events.
- AutoscalerEventHandlerFactory - Class in org.apache.flink.autoscaler.standalone
-
The factory of
AutoScalerEventHandler
. - AutoscalerEventHandlerFactory() - Constructor for class org.apache.flink.autoscaler.standalone.AutoscalerEventHandlerFactory
- AutoscalerEventHandlerFactory.EventHandlerType - Enum in org.apache.flink.autoscaler.standalone
-
Out-of-box event handler type.
- AutoscalerEventUtils - Class in org.apache.flink.autoscaler.event
-
The utils of
AutoScalerEventHandler
. - AutoscalerEventUtils() - Constructor for class org.apache.flink.autoscaler.event.AutoscalerEventUtils
- AutoscalerFactory - Class in org.apache.flink.kubernetes.operator.autoscaler
-
The factory of
JobAutoScaler
. - AutoscalerFactory() - Constructor for class org.apache.flink.kubernetes.operator.autoscaler.AutoscalerFactory
- AutoscalerFlinkMetrics - Class in org.apache.flink.autoscaler.metrics
-
Autoscaler metrics for observability.
- AutoscalerFlinkMetrics(MetricGroup) - Constructor for class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- AutoScalerOptions - Class in org.apache.flink.autoscaler.config
-
Config options related to the autoscaler module.
- AutoScalerOptions() - Constructor for class org.apache.flink.autoscaler.config.AutoScalerOptions
- AutoScalerSerDeModule - Class in org.apache.flink.autoscaler.utils
-
Jackson serializer module for
JobVertexID
. - AutoScalerSerDeModule() - Constructor for class org.apache.flink.autoscaler.utils.AutoScalerSerDeModule
- AutoscalerStandaloneOptions - Class in org.apache.flink.autoscaler.standalone.config
-
Config options related to the autoscaler standalone module.
- AutoscalerStandaloneOptions() - Constructor for class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- AutoScalerStateStore<KEY,Context extends JobAutoScalerContext<KEY>> - Interface in org.apache.flink.autoscaler.state
-
The state store is responsible for storing all state during scaling.
- AutoscalerStateStoreFactory - Class in org.apache.flink.autoscaler.standalone
-
The factory of
AutoScalerStateStore
. - AutoscalerStateStoreFactory() - Constructor for class org.apache.flink.autoscaler.standalone.AutoscalerStateStoreFactory
- AutoscalerStateStoreFactory.StateStoreType - Enum in org.apache.flink.autoscaler.standalone
-
Out-of-box state store type.
- AutoScalerUtils - Class in org.apache.flink.autoscaler.utils
-
AutoScaler utilities.
- AutoScalerUtils() - Constructor for class org.apache.flink.autoscaler.utils.AutoScalerUtils
- autoscaling - package autoscaling
- AutoscalingExample - Class in autoscaling
-
Autoscaling Example.
- AutoscalingExample() - Constructor for class autoscaling.AutoscalingExample
- AVERAGE - Static variable in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- avg(double) - Static method in class org.apache.flink.autoscaler.metrics.EvaluatedScalingMetric
- AVG - org.apache.flink.autoscaler.metrics.MetricAggregator
B
- BACKLOG_PROCESSING_LAG_THRESHOLD - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- BACKPRESSURE_TIME_PER_SEC - org.apache.flink.autoscaler.metrics.FlinkMetric
- before(BasicBuilder, HttpRequest, Interceptor.RequestTags) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- BROADCAST - org.apache.flink.autoscaler.topology.ShipStrategy
- budget(long) - Method in class org.apache.flink.autoscaler.tuning.MemoryBudget
- build() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- build() - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.DiffBuilder
- build() - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.ReflectiveDiffBuilder
- buildFrom(String, String, FlinkDeploymentSpec, Configuration) - Static method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- buildKubernetesJobManagerSpecification(FlinkPod, StandaloneKubernetesJobManagerParameters) - Static method in class org.apache.flink.kubernetes.operator.kubeclient.factory.StandaloneKubernetesJobManagerFactory
- buildKubernetesTaskManagerDeployment(FlinkPod, StandaloneKubernetesTaskManagerParameters) - Static method in class org.apache.flink.kubernetes.operator.kubeclient.factory.StandaloneKubernetesTaskManagerFactory
- BUSY_TIME_AGGREGATOR - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- BUSY_TIME_PER_SEC - org.apache.flink.autoscaler.metrics.FlinkMetric
C
- calculateClusterCpuUsage(Configuration, int) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- calculateClusterMemoryUsage(Configuration, int) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- CalendarUtils - Class in org.apache.flink.autoscaler.utils
-
Calendar utilities.
- CalendarUtils() - Constructor for class org.apache.flink.autoscaler.utils.CalendarUtils
- CANARY_LABEL - Static variable in class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- CANARY_RESOURCE_TIMEOUT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- CanaryResourceManager<CR extends AbstractFlinkResource<?,?>> - Class in org.apache.flink.kubernetes.operator.health
-
Logic encapsulating canary tests.
- CanaryResourceManager() - Constructor for class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- CANCEL - org.apache.flink.kubernetes.operator.service.SuspendMode
- cancelJob(FlinkDeployment, SuspendMode, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- cancelJob(FlinkDeployment, SuspendMode, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- cancelJob(FlinkDeployment, SuspendMode, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- cancelJob(FlinkDeployment, SuspendMode, Configuration, boolean) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- cancelJob(FlinkResourceContext<CR>, SuspendMode) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
-
Cancel the job for the given resource using the specified upgrade mode.
- cancelJob(FlinkResourceContext<FlinkDeployment>, SuspendMode) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.ApplicationReconciler
- cancelJob(FlinkResourceContext<FlinkSessionJob>, SuspendMode) - Method in class org.apache.flink.kubernetes.operator.reconciler.sessionjob.SessionJobReconciler
- cancelJobOrError(RestClusterClient<String>, CommonStatus<?>, boolean) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- cancelPending() - Method in class org.apache.flink.kubernetes.operator.resources.ClusterResourceView
- CancelResult() - Constructor for class org.apache.flink.kubernetes.operator.service.FlinkService.CancelResult
- cancelSessionJob(FlinkSessionJob, SuspendMode, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- cancelSessionJob(FlinkSessionJob, SuspendMode, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- CANONICAL - org.apache.flink.kubernetes.operator.api.status.SavepointFormatType
-
A canonical, common for all state backends format.
- CATCH_UP_DATA_RATE - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Target processing rate of operators as derived from backlog (records/sec).
- CATCH_UP_DURATION - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.kubernetes.operator.health.OperatorHealthHandler
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class org.apache.flink.kubernetes.operator.admission.AdmissionHandler
- checkAndUpdateStableSpec(CommonStatus<?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
Checks the status and if the corresponding Flink job/application is in stable running state, it updates the last stable spec.
- checkHealth(ResourceID, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- checkIfAlreadyUpgraded(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.observer.AbstractFlinkResourceObserver
-
Checks a resource that is currently in the UPGRADING state whether it was already deployed but we simply miss the status information.
- checkIfAlreadyUpgraded(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- checkIfAlreadyUpgraded(FlinkResourceContext<FlinkSessionJob>) - Method in class org.apache.flink.kubernetes.operator.observer.sessionjob.FlinkSessionJobObserver
- checkObjectCompatibility(String, JsonNode, JsonNode) - Static method in class org.apache.flink.kubernetes.operator.api.validation.CrdCompatibilityChecker
- Checkpoint - Class in org.apache.flink.kubernetes.operator.api.status
-
Represents information about a finished checkpoint.
- Checkpoint(long, SnapshotTriggerType, CheckpointType, Long) - Constructor for class org.apache.flink.kubernetes.operator.api.status.Checkpoint
- CHECKPOINT - org.apache.flink.kubernetes.operator.reconciler.SnapshotType
- CHECKPOINT_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkStateSnapshotMetrics
- CheckpointError - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- CheckpointFetchResult - Class in org.apache.flink.kubernetes.operator.observer
-
Result of a fetch checkpoint operation.
- CheckpointFetchResult() - Constructor for class org.apache.flink.kubernetes.operator.observer.CheckpointFetchResult
- CheckpointHistoryWrapper - Class in org.apache.flink.kubernetes.operator.service
-
Custom Response for handling checkpoint history in a multi-version compatible way.
- CheckpointHistoryWrapper() - Constructor for class org.apache.flink.kubernetes.operator.service.CheckpointHistoryWrapper
- CheckpointHistoryWrapper.CompletedCheckpointInfo - Class in org.apache.flink.kubernetes.operator.service
-
Information about the latest completed checkpoint/savepoint.
- CheckpointHistoryWrapper.PendingCheckpointInfo - Class in org.apache.flink.kubernetes.operator.service
-
Information about the currently pending checkpoint/savepoint.
- CheckpointInfo - Class in org.apache.flink.kubernetes.operator.api.status
-
Deprecated.
- CheckpointInfo() - Constructor for class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- checkpointInProgress(JobStatus) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
- CheckpointSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
Spec for checkpoint state snapshots.
- CheckpointSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.CheckpointSpec
- CheckpointStatsResult - Class in org.apache.flink.kubernetes.operator.observer
-
Result of fetching checkpoint stats, currently consisting only of its result path.
- CheckpointStatsResult() - Constructor for class org.apache.flink.kubernetes.operator.observer.CheckpointStatsResult
- CheckpointType - Enum in org.apache.flink.kubernetes.operator.api.status
-
Checkpoint format type.
- checkStringTypeCompatibility(String, JsonNode, JsonNode) - Static method in class org.apache.flink.kubernetes.operator.api.validation.CrdCompatibilityChecker
- checkTypeCompatibility(String, JsonNode, JsonNode) - Static method in class org.apache.flink.kubernetes.operator.api.validation.CrdCompatibilityChecker
- cipherSuites() - Method in class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- cleanup(CR) - Method in class org.apache.flink.kubernetes.operator.service.FlinkResourceContextFactory
- cleanup(KEY) - Method in interface org.apache.flink.autoscaler.JobAutoScaler
-
Called when the job is deleted.
- cleanup(KEY) - Method in class org.apache.flink.autoscaler.JobAutoScalerImpl
- cleanup(KEY) - Method in class org.apache.flink.autoscaler.NoopJobAutoscaler
- cleanup(KEY) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- cleanup(FlinkDeployment, Context) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentController
- cleanup(FlinkSessionJob, Context) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobController
- cleanup(FlinkStateSnapshot, Context<FlinkStateSnapshot>) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotController
- cleanup(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- cleanup(FlinkResourceContext<CR>) - Method in interface org.apache.flink.kubernetes.operator.reconciler.Reconciler
-
This is called when receiving the delete event of custom resource.
- cleanup(FlinkStateSnapshotContext) - Method in class org.apache.flink.kubernetes.operator.reconciler.snapshot.StateSnapshotReconciler
- Cleanup - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- cleanupAfterFailedJob(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
-
Removes a failed job.
- cleanupAfterFailedJob(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.ApplicationReconciler
- cleanupAfterFailedJob(FlinkResourceContext<FlinkSessionJob>) - Method in class org.apache.flink.kubernetes.operator.reconciler.sessionjob.SessionJobReconciler
- cleanupDoneFor(ResourceID, Map<String, Object>) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- CleanupFailed - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- cleanupInternal(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
-
Shut down and clean up all Flink job/cluster resources.
- cleanupInternal(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.ApplicationReconciler
- cleanupInternal(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.SessionReconciler
- cleanupInternal(FlinkResourceContext<FlinkSessionJob>) - Method in class org.apache.flink.kubernetes.operator.reconciler.sessionjob.SessionJobReconciler
- cleanupTmpFiles(Configuration) - Static method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- clear() - Method in class org.apache.flink.autoscaler.jdbc.state.JobStateView
- clearAll(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- clearAll(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
-
Removes all data from this context.
- clearAll(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- clearAll(String) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateStore
- clearAll(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- clearAll(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- clearErrorsIfDeploymentIsHealthy(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- clearLastReconciledSpecIfFirstDeploy(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
Clear last reconciled spec if that corresponds to the first deployment.
- clock - Variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- clone(T) - Static method in class org.apache.flink.kubernetes.operator.api.utils.SpecUtils
- clone(T) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- close() - Method in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
-
Close the related resource.
- close() - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcAutoScalerEventHandler
- close() - Method in class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerExecutor
- CLUSTER_MODE - Static variable in class org.apache.flink.kubernetes.operator.standalone.StandaloneKubernetesConfigOptionsInternal
- ClusterHealthEvaluator - Class in org.apache.flink.kubernetes.operator.observer
-
Evaluates whether the cluster is healthy.
- ClusterHealthEvaluator(Clock) - Constructor for class org.apache.flink.kubernetes.operator.observer.ClusterHealthEvaluator
- ClusterHealthInfo - Class in org.apache.flink.kubernetes.operator.health
-
Represents information about job health.
- ClusterHealthInfo() - Constructor for class org.apache.flink.kubernetes.operator.health.ClusterHealthInfo
- ClusterHealthInfo(Clock) - Constructor for class org.apache.flink.kubernetes.operator.health.ClusterHealthInfo
- ClusterHealthObserver - Class in org.apache.flink.kubernetes.operator.observer
-
An observer to observe the cluster health.
- ClusterHealthObserver() - Constructor for class org.apache.flink.kubernetes.operator.observer.ClusterHealthObserver
- ClusterResourceManager - Class in org.apache.flink.kubernetes.operator.resources
-
A cluster resource manager which provides a view over the allocatable resources within a Kubernetes cluster and allows to simulate scheduling pods with a defined number of required resources.
- ClusterResourceManager(Duration, KubernetesClient) - Constructor for class org.apache.flink.kubernetes.operator.resources.ClusterResourceManager
- ClusterResourceView - Class in org.apache.flink.kubernetes.operator.resources
-
A view on Kubernetes cluster resources by nodes and their cpu/memory.
- ClusterResourceView() - Constructor for class org.apache.flink.kubernetes.operator.resources.ClusterResourceView
- CmdStandaloneJobManagerDecorator - Class in org.apache.flink.kubernetes.operator.kubeclient.decorators
-
Attach the command and args to the main container for running the JobManager in standalone mode.
- CmdStandaloneJobManagerDecorator(StandaloneKubernetesJobManagerParameters) - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneJobManagerDecorator
- CmdStandaloneTaskManagerDecorator - Class in org.apache.flink.kubernetes.operator.kubeclient.decorators
-
Attach the command and args to the main container for running the TaskManager in standalone mode.
- CmdStandaloneTaskManagerDecorator(StandaloneKubernetesTaskManagerParameters) - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneTaskManagerDecorator
- COLLECTED_METRICS - org.apache.flink.autoscaler.jdbc.state.StateType
- COLLECTED_METRICS_KEY - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- CollectedMetricHistory - Class in org.apache.flink.autoscaler.metrics
-
Topology and collected metric history.
- CollectedMetricHistory() - Constructor for class org.apache.flink.autoscaler.metrics.CollectedMetricHistory
- CollectedMetrics - Class in org.apache.flink.autoscaler.metrics
-
Collected scaling metrics.
- CollectedMetrics() - Constructor for class org.apache.flink.autoscaler.metrics.CollectedMetrics
- commit() - Method in class org.apache.flink.kubernetes.operator.resources.ClusterResourceView
- commitPending() - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesNodeResourceInfo
- commitPending() - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesResource
- CommonStatus<SPEC extends AbstractFlinkSpec> - Class in org.apache.flink.kubernetes.operator.api.status
-
Last observed common status of the Flink deployment/Flink SessionJob.
- CommonStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.CommonStatus
- CompatibilityError(String) - Constructor for exception org.apache.flink.kubernetes.operator.api.validation.CrdCompatibilityChecker.CompatibilityError
- completed(Long) - Static method in class org.apache.flink.kubernetes.operator.observer.CheckpointFetchResult
- completed(String) - Static method in class org.apache.flink.kubernetes.operator.observer.CheckpointStatsResult
- completed(String) - Static method in class org.apache.flink.kubernetes.operator.observer.SavepointFetchResult
- completed(String) - Static method in class org.apache.flink.kubernetes.operator.service.FlinkService.CancelResult
- COMPLETED - org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus.State
-
Snapshot was successful and available.
- CompletedCheckpointInfo() - Constructor for class org.apache.flink.kubernetes.operator.service.CheckpointHistoryWrapper.CompletedCheckpointInfo
- computeBusyTimeAvg(Configuration, SortedMap<Instant, CollectedMetrics>, JobVertexID, int) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
-
Compute the average busy time for the given vertex for the current metric window.
- computeDataRateMetrics(JobVertexID, Map<FlinkMetric, AggregatedMetric>, Map<ScalingMetric, Double>, JobTopology, Configuration, Supplier<Double>) - Static method in class org.apache.flink.autoscaler.metrics.ScalingMetrics
- computeEdgeDataRate(JobTopology, SortedMap<Instant, CollectedMetrics>, JobVertexID, JobVertexID) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
-
Compute how many records flow between two job vertices in the pipeline.
- computeEdgeOutputRatio(JobVertexID, JobVertexID, JobTopology, SortedMap<Instant, CollectedMetrics>) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
-
Compute the In/Out ratio between the (from, to) vertices.
- computeGlobalMetrics(Map<FlinkMetric, Metric>, Map<FlinkMetric, AggregatedMetric>, Configuration) - Static method in class org.apache.flink.autoscaler.metrics.ScalingMetrics
- computeLagMetrics(Map<FlinkMetric, AggregatedMetric>, Map<ScalingMetric, Double>) - Static method in class org.apache.flink.autoscaler.metrics.ScalingMetrics
- computeLoadMetrics(JobVertexID, Map<FlinkMetric, AggregatedMetric>, Map<ScalingMetric, Double>, IOMetrics, Configuration) - Static method in class org.apache.flink.autoscaler.metrics.ScalingMetrics
- computeNewParallelisms(Map<JobVertexID, ScalingSummary>, Map<JobVertexID, Map<ScalingMetric, EvaluatedScalingMetric>>) - Static method in class org.apache.flink.autoscaler.utils.ResourceCheckUtils
- computeObservedTprWithBackpressure(double, double) - Static method in class org.apache.flink.autoscaler.metrics.ScalingMetrics
- computeProcessingRateThresholds(Map<ScalingMetric, EvaluatedScalingMetric>, Configuration, boolean, Duration) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
- computeScaleTargetParallelism(Context, JobVertexID, Collection<ShipStrategy>, Map<ScalingMetric, EvaluatedScalingMetric>, SortedMap<Instant, ScalingSummary>, Duration, DelayedScaleDown) - Method in class org.apache.flink.autoscaler.JobVertexScaler
- computeTrueProcessingRate(double, double, SortedMap<Instant, CollectedMetrics>, JobVertexID, Configuration) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
-
Compute the true processing rate for the given vertex for the current metric window.
- CONFIG_OVERRIDES - org.apache.flink.autoscaler.jdbc.state.StateType
- CONFIG_OVERRIDES_KEY - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- ConfigChanges - Class in org.apache.flink.autoscaler.tuning
-
Holds the configuration overrides and removals for a Flink Configuration.
- ConfigChanges() - Constructor for class org.apache.flink.autoscaler.tuning.ConfigChanges
- configManager - Variable in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
- ConfigMapStore - Class in org.apache.flink.kubernetes.operator.autoscaler.state
-
The ConfigMapStore persists state in Kubernetes ConfigMaps.
- ConfigMapStore(KubernetesClient) - Constructor for class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- ConfigOptionsDocGenerator - Class in org.apache.flink.kubernetes.operator.docs.configuration
-
Class used for generating code based documentation of configuration parameters.
- ConfigOptionUtils - Class in org.apache.flink.kubernetes.operator.utils
-
ConfigOption
utilities. - ConfigOptionUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.ConfigOptionUtils
- CONTROL_LOOP_INTERVAL - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- CONTROL_LOOP_PARALLELISM - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- COUNTER - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- COUNTER_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkStateSnapshotMetrics
- COUNTER_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- COUNTER_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkSessionJobMetrics
- CPU_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- CPU_QUOTA - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- CR_GENERATION_LABEL - Static variable in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- CrdCompatibilityChecker - Class in org.apache.flink.kubernetes.operator.api.validation
-
Utility for checking backward CRD compatibility.
- CrdCompatibilityChecker() - Constructor for class org.apache.flink.kubernetes.operator.api.validation.CrdCompatibilityChecker
- CrdCompatibilityChecker.CompatibilityError - Exception in org.apache.flink.kubernetes.operator.api.validation
-
Compatibility Error class.
- CrdConstants - Class in org.apache.flink.kubernetes.operator.api
-
Constants used by the CRD.
- CrdConstants() - Constructor for class org.apache.flink.kubernetes.operator.api.CrdConstants
- CrdReferenceDoclet - Class in org.apache.flink.kubernetes.operator.api.docs
-
Doclet for generating the FlinkDeployment CRD reference.
- CrdReferenceDoclet() - Constructor for class org.apache.flink.kubernetes.operator.api.docs.CrdReferenceDoclet
- create(KubernetesClient, Collection<FlinkResourceListener>) - Static method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- create(KubernetesClient, MetricManager<CR>, Collection<FlinkResourceListener>) - Static method in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
- create(KubernetesClient, EventRecorder, ClusterResourceManager) - Static method in class org.apache.flink.kubernetes.operator.autoscaler.AutoscalerFactory
- create(Configuration) - Static method in class org.apache.flink.autoscaler.standalone.AutoscalerEventHandlerFactory
- create(Configuration) - Static method in class org.apache.flink.autoscaler.standalone.AutoscalerStateStoreFactory
- create(Configuration, ExecutorService) - Static method in class org.apache.flink.kubernetes.operator.kubeclient.Fabric8FlinkStandaloneKubeClient
- create(MetricRegistry, Configuration, String, String, String) - Static method in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- createCheckpointResource(KubernetesClient, AbstractFlinkResource<?, ?>, SnapshotTriggerType) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Creates a checkpoint
FlinkStateSnapshot
resource on the Kubernetes cluster. - CREATED - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- createData(String, List<StateType>, Map<StateType, String>) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateInteractor
- createEvent(String, String, AutoScalerEventHandler.Type, String, String) - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcEventInteractor
- createFlinkDeploymentMetricManager(Configuration, KubernetesOperatorMetricGroup) - Static method in class org.apache.flink.kubernetes.operator.metrics.MetricManager
- createFlinkService() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
- createFlinkService() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobContext
- createFlinkSessionJobMetricManager(Configuration, KubernetesOperatorMetricGroup) - Static method in class org.apache.flink.kubernetes.operator.metrics.MetricManager
- createFlinkStateSnapshot(KubernetesClient, String, String, FlinkStateSnapshotSpec, SnapshotTriggerType) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
- createFlinkStateSnapshotMetricManager(Configuration, KubernetesOperatorMetricGroup) - Static method in class org.apache.flink.kubernetes.operator.metrics.MetricManager
- createForFlinkStateSnapshot(KubernetesClient, MetricManager<FlinkStateSnapshot>, Collection<FlinkResourceListener>) - Static method in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
- createFromIdentifier(String) - Static method in enum org.apache.flink.autoscaler.jdbc.state.StateType
- createHistogram(FlinkOperatorConfiguration) - Static method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils
- createIfNotExists(KubernetesClient, HasMetadata, EventRecorder.Type, String, String, EventRecorder.Component, Consumer<Event>, String) - Static method in class org.apache.flink.kubernetes.operator.utils.EventUtils
- createMetricConfig(Configuration) - Static method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils
- createNamespacedKubeClient(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- createObserveConfig() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentContext
- createObserveConfig() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
-
Generate the config that is currently deployed for the resource spec.
- createObserveConfig() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobContext
- createOperator() - Method in class org.apache.flink.kubernetes.operator.FlinkOperator
- createOrUpdateEventWithInterval(KubernetesClient, HasMetadata, EventRecorder.Type, String, String, EventRecorder.Component, Consumer<Event>, String, Duration) - Static method in class org.apache.flink.kubernetes.operator.utils.EventUtils
- createOrUpdateEventWithLabels(KubernetesClient, HasMetadata, EventRecorder.Type, String, String, EventRecorder.Component, Consumer<Event>, String, Duration, Predicate<Map<String, String>>, Map<String, String>) - Static method in class org.apache.flink.kubernetes.operator.utils.EventUtils
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceMetricGroup
- createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceMetricGroup
- createResourceGroup(Configuration, String) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceMetricGroup
- createResourceMetricGroup(KubernetesOperatorMetricGroup, FlinkConfigManager, AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils
- createResourceNamespaceGroup(Configuration, Class<? extends CustomResource>, String) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- createSavepointResource(KubernetesClient, AbstractFlinkResource<?, ?>, String, SnapshotTriggerType, SavepointFormatType, boolean) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Creates a checkpoint
FlinkStateSnapshot
resource on the Kubernetes cluster. - createTaskManagerDeployment(Deployment) - Method in class org.apache.flink.kubernetes.operator.kubeclient.Fabric8FlinkStandaloneKubeClient
- createTaskManagerDeployment(Deployment) - Method in interface org.apache.flink.kubernetes.operator.kubeclient.FlinkStandaloneKubeClient
- createUpgradeSnapshotResource(Configuration, FlinkOperatorConfiguration, KubernetesClient, AbstractFlinkResource<?, ?>, SavepointFormatType, String) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
For an upgrade savepoint, create a
FlinkStateSnapshot
on the Kubernetes cluster. - current() - Static method in enum org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
-
Returns the current version.
- CURRENT - Static variable in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- CUSTOM - org.apache.flink.autoscaler.topology.ShipStrategy
- CustomCheckpointingStatisticsHeaders - Class in org.apache.flink.kubernetes.operator.service
-
Custom Headers for handling checkpoint history in a multi-version compatible way.
- CustomCheckpointingStatisticsHeaders() - Constructor for class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- CustomDashboardConfiguration - Class in org.apache.flink.kubernetes.operator.service
-
Custom Response for handling dashboard configs.
- CustomDashboardConfiguration() - Constructor for class org.apache.flink.kubernetes.operator.service.CustomDashboardConfiguration
- CustomDashboardConfigurationHeaders - Class in org.apache.flink.kubernetes.operator.service
-
Message headers for the
CustomDashboardConfiguration
. - CustomResourceMetrics<CR extends io.fabric8.kubernetes.client.CustomResource<?,?>> - Interface in org.apache.flink.kubernetes.operator.metrics
-
Custom resource metric type.
D
- DateTimeUtils - Class in org.apache.flink.autoscaler.utils
-
Date and time related utilities.
- DateTimeUtils() - Constructor for class org.apache.flink.autoscaler.utils.DateTimeUtils
- dec() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedCounter
- dec(long) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedCounter
- decorateFlinkPod(FlinkPod) - Method in class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneJobManagerDecorator
- decorateFlinkPod(FlinkPod) - Method in class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneTaskManagerDecorator
- decorateFlinkPod(FlinkPod) - Method in class org.apache.flink.kubernetes.operator.kubeclient.decorators.InitStandaloneTaskManagerDecorator
- decorateFlinkPod(FlinkPod) - Method in class org.apache.flink.kubernetes.operator.kubeclient.decorators.UserLibMountDecorator
- DEFAULT_CHECKPOINTING_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- DefaultFlinkMutator - Class in org.apache.flink.kubernetes.operator.mutator
-
Default Flink Mutator.
- DefaultFlinkMutator() - Constructor for class org.apache.flink.kubernetes.operator.mutator.DefaultFlinkMutator
- DefaultRequestMutator<T extends io.fabric8.kubernetes.api.model.KubernetesResource> - Class in org.apache.flink.kubernetes.operator.admission.mutator
-
The default request mutator.
- DefaultRequestMutator(Mutator<T>) - Constructor for class org.apache.flink.kubernetes.operator.admission.mutator.DefaultRequestMutator
- DefaultRequestMutator(Mutator<T>, Cloner<T>) - Constructor for class org.apache.flink.kubernetes.operator.admission.mutator.DefaultRequestMutator
- DefaultValidator - Class in org.apache.flink.kubernetes.operator.validation
-
Default validator implementation for
FlinkDeployment
. - DefaultValidator(FlinkConfigManager) - Constructor for class org.apache.flink.kubernetes.operator.validation.DefaultValidator
- DELAYED_SCALE_DOWN - org.apache.flink.autoscaler.jdbc.state.StateType
- DELAYED_SCALE_DOWN - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- DelayedScaleDown - Class in org.apache.flink.autoscaler
-
All delayed scale down requests.
- DelayedScaleDown() - Constructor for class org.apache.flink.autoscaler.DelayedScaleDown
- DelayedScaleDown(Map<JobVertexID, Instant>) - Constructor for class org.apache.flink.autoscaler.DelayedScaleDown
- deleteBlocking(String, Callable<Waitable>, Duration) - Static method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
-
Generic blocking delete operation implementation for triggering and waiting for removal of the selected resources.
- deleteCluster() - Method in enum org.apache.flink.kubernetes.operator.service.SuspendMode
- deleteClusterDeployment(ObjectMeta, FlinkDeploymentStatus, Configuration, boolean) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- deleteClusterDeployment(ObjectMeta, FlinkDeploymentStatus, Configuration, boolean) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- deleteClusterInternal(String, String, Configuration, DeletionPropagation) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
-
Delete Flink kubernetes cluster by deleting the kubernetes resources directly.
- deleteClusterInternal(String, String, Configuration, DeletionPropagation) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- deleteClusterInternal(String, String, Configuration, DeletionPropagation) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- deleteData(String, List<StateType>) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateInteractor
- deleteDeploymentBlocking(String, Resource<Deployment>, DeletionPropagation, Duration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
-
Wait until Deployment is removed, return remaining timeout.
- deleteHAData(String, String, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- deleteHaMeta() - Method in enum org.apache.flink.kubernetes.operator.service.SuspendMode
- deleteJobGraphInKubernetesHA(String, String, KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- deleteJobGraphInZookeeperHA(Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- deleteKubernetesHAMetadata(String, String, KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- deleteZookeeperHAMetadata(Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- deploy(FlinkResourceContext<CR>, SPEC, Configuration, Optional<String>, boolean) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
-
Deploys the target resource spec to Kubernetes.
- deploy(FlinkResourceContext<FlinkDeployment>, FlinkDeploymentSpec, Configuration, Optional<String>, boolean) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.ApplicationReconciler
- deploy(FlinkResourceContext<FlinkDeployment>, FlinkDeploymentSpec, Configuration, Optional<String>, boolean) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.SessionReconciler
- deploy(FlinkResourceContext<FlinkSessionJob>, FlinkSessionJobSpec, Configuration, Optional<String>, boolean) - Method in class org.apache.flink.kubernetes.operator.reconciler.sessionjob.SessionJobReconciler
- deployApplicationCluster(ClusterSpecification, ApplicationConfiguration) - Method in class org.apache.flink.kubernetes.operator.standalone.KubernetesStandaloneClusterDescriptor
- deployApplicationCluster(JobSpec, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- deployApplicationCluster(JobSpec, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- deployApplicationCluster(JobSpec, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- DEPLOYED - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- DEPLOYED - org.apache.flink.kubernetes.operator.api.status.ReconciliationState
-
The lastReconciledSpec is currently deployed.
- DEPLOYED_NOT_READY - org.apache.flink.kubernetes.operator.api.status.JobManagerDeploymentStatus
-
JobManager is running but not ready yet to receive REST API calls.
- DEPLOYING - org.apache.flink.kubernetes.operator.api.status.JobManagerDeploymentStatus
-
JobManager process is starting up.
- DEPLOYMENT_READINESS_TIMEOUT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- DEPLOYMENT_ROLLBACK_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- DeploymentFailedException - Exception in org.apache.flink.kubernetes.operator.exception
-
Exception to signal terminal deployment failure.
- DeploymentFailedException(DeploymentCondition) - Constructor for exception org.apache.flink.kubernetes.operator.exception.DeploymentFailedException
- DeploymentFailedException(ContainerStateWaiting) - Constructor for exception org.apache.flink.kubernetes.operator.exception.DeploymentFailedException
- DeploymentFailedException(String, String) - Constructor for exception org.apache.flink.kubernetes.operator.exception.DeploymentFailedException
- deploySessionCluster(ClusterSpecification) - Method in class org.apache.flink.kubernetes.operator.standalone.KubernetesStandaloneClusterDescriptor
- deploySessionCluster(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- deploySessionCluster(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- deploySessionCluster(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- deserialize(String) - Static method in class org.apache.flink.kubernetes.operator.health.ClusterHealthInfo
- deserialize(JsonParser, DeserializationContext) - Method in class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDDeserializer
- deserializeLastReconciledSpec() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- deserializeLastReconciledSpecWithMeta() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- deserializeLastStableSpec() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- deserializeLastStableSpecWithMeta() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- deserializeSpecWithMeta(String, Class<T>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.SpecUtils
-
Deserializes the spec and custom metadata object from JSON.
- Diff<T> - Class in org.apache.flink.kubernetes.operator.reconciler.diff
-
Contains the differences between two
Diffable
class fields. - Diff() - Constructor for class org.apache.flink.kubernetes.operator.reconciler.diff.Diff
- Diffable<T> - Interface in org.apache.flink.kubernetes.operator.api.diff
- DiffBuilder<T> - Class in org.apache.flink.kubernetes.operator.reconciler.diff
-
Assists in implementing comparison of
Diffable
instances. - DiffBuilder(T, T) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.diff.DiffBuilder
- DiffResult<T> - Class in org.apache.flink.kubernetes.operator.reconciler.diff
-
Contains a collection of the differences between two
Diffable
objects. - DiffType - Enum in org.apache.flink.kubernetes.operator.api.diff
-
Spec change type.
- discoverListeners(FlinkConfigManager) - Static method in class org.apache.flink.kubernetes.operator.listener.ListenerUtils
-
Load
FlinkResourceListener
implementations from the plugin directory. - discoverMutators(FlinkConfigManager) - Static method in class org.apache.flink.kubernetes.operator.utils.MutatorUtils
-
discovers mutators.
- discoverValidators(FlinkConfigManager) - Static method in class org.apache.flink.kubernetes.operator.utils.ValidatorUtils
- disposeSavepoint(String, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- disposeSavepoint(String, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- DRAIN_ON_SAVEPOINT_DELETION - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
E
- Edge - Class in org.apache.flink.autoscaler.metrics
-
Collected scaling metrics.
- Edge() - Constructor for class org.apache.flink.autoscaler.metrics.Edge
- ENV_CONF_OVERRIDE_DIR - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_HOSTNAME - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_KUBERNETES_SERVICE_HOST - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_OPERATOR_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_OPERATOR_KEYSTORE_PATH - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_OPERATOR_NAME - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_OPERATOR_NAMESPACE - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_OPERATOR_TRUSTSTORE_PATH - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_WATCH_NAMESPACES - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_WEBHOOK_KEYSTORE_FILE - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_WEBHOOK_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_WEBHOOK_KEYSTORE_TYPE - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- ENV_WEBHOOK_SERVER_PORT - Static variable in class org.apache.flink.kubernetes.operator.utils.EnvUtils
- EnvUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Util to get value from environments.
- EnvUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.EnvUtils
- EPHEMERAL_STORAGE - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- equals(Object) - Method in class org.apache.flink.autoscaler.JobVertexScaler.ParallelismChange
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- equals(Object) - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- error(String) - Static method in class org.apache.flink.kubernetes.operator.observer.CheckpointFetchResult
- error(String) - Static method in class org.apache.flink.kubernetes.operator.observer.CheckpointStatsResult
- error(String) - Static method in class org.apache.flink.kubernetes.operator.observer.SavepointFetchResult
- ERROR - org.apache.flink.kubernetes.operator.api.status.JobManagerDeploymentStatus
-
Deployment in terminal error, requires spec change for reconciliation to continue.
- escapeCharacters(String) - Static method in class org.apache.flink.kubernetes.operator.docs.util.Utils
- estimateNumTaskSlotsAfterRescale(Map<JobVertexID, Map<ScalingMetric, EvaluatedScalingMetric>>, Map<JobVertexID, ScalingSummary>, int) - Static method in class org.apache.flink.autoscaler.utils.ResourceCheckUtils
- evaluate(Configuration, Map<String, String>, ClusterHealthInfo) - Method in class org.apache.flink.kubernetes.operator.observer.ClusterHealthEvaluator
- evaluate(Configuration, CollectedMetricHistory, Duration) - Method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
- EvaluatedMetrics - Class in org.apache.flink.autoscaler.metrics
-
Collected scaling metrics.
- EvaluatedMetrics() - Constructor for class org.apache.flink.autoscaler.metrics.EvaluatedMetrics
- EvaluatedScalingMetric - Class in org.apache.flink.autoscaler.metrics
-
Evaluated scaling metric.
- EvaluatedScalingMetric(double, double) - Constructor for class org.apache.flink.autoscaler.metrics.EvaluatedScalingMetric
- evaluateGlobalMetrics(SortedMap<Instant, CollectedMetrics>) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
- EVENT_HANDLER_TYPE - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- eventRecorder - Variable in class org.apache.flink.kubernetes.operator.observer.AbstractFlinkResourceObserver
- eventRecorder - Variable in class org.apache.flink.kubernetes.operator.observer.JobStatusObserver
- eventRecorder - Variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- EventRecorder - Class in org.apache.flink.kubernetes.operator.utils
-
Helper class for creating Kubernetes events for Flink resources.
- EventRecorder(BiConsumer<AbstractFlinkResource<?, ?>, Event>, BiConsumer<FlinkStateSnapshot, Event>) - Constructor for class org.apache.flink.kubernetes.operator.utils.EventRecorder
- EventRecorder.Component - Enum in org.apache.flink.kubernetes.operator.utils
-
The component of events.
- EventRecorder.Reason - Enum in org.apache.flink.kubernetes.operator.utils
-
The reason codes of events.
- EventRecorder.Type - Enum in org.apache.flink.kubernetes.operator.utils
-
The type of the events.
- EventSourceUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Utility class to locate secondary resources.
- EventSourceUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.EventSourceUtils
- EventUtils - Class in org.apache.flink.kubernetes.operator.utils
-
The util to generate an event for the target resource.
- EventUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.EventUtils
- EXCLUDED_PERIODS - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- excludeVertexFromScaling(Configuration, JobVertexID) - Static method in class org.apache.flink.autoscaler.utils.AutoScalerUtils
-
Temporarily exclude vertex from scaling for this run.
- excludeVerticesFromScaling(Configuration, Collection<JobVertexID>) - Static method in class org.apache.flink.autoscaler.utils.AutoScalerUtils
- executorService - Variable in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- EXPECTED_PROCESSING_RATE - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Expected true processing rate after scale up.
- EXTRACT_SNAPSHOT_TIME - Static variable in class org.apache.flink.kubernetes.operator.observer.SnapshotObserver
F
- Fabric8FlinkStandaloneKubeClient - Class in org.apache.flink.kubernetes.operator.kubeclient
-
The Implementation of
FlinkStandaloneKubeClient
. - Fabric8FlinkStandaloneKubeClient(Configuration, NamespacedKubernetesClient, ExecutorService) - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.Fabric8FlinkStandaloneKubeClient
- FAILED - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- FAILED - org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus.State
-
Error during snapshot.
- failedReconciliation(ResourceID, Exception, Map<String, Object>) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- fetch(String, Configuration, File) - Method in interface org.apache.flink.kubernetes.operator.artifact.ArtifactFetcher
-
Fetch the resource from the uri to the targetDir.
- fetch(String, Configuration, File) - Method in class org.apache.flink.kubernetes.operator.artifact.FileSystemBasedArtifactFetcher
- fetch(String, Configuration, File) - Method in class org.apache.flink.kubernetes.operator.artifact.HttpArtifactFetcher
- fetch(String, Configuration, String) - Method in class org.apache.flink.kubernetes.operator.artifact.ArtifactManager
- fetch(Configuration) - Method in class org.apache.flink.autoscaler.standalone.flinkcluster.FlinkClusterJobListFetcher
- fetch(Configuration) - Method in interface org.apache.flink.autoscaler.standalone.JobListFetcher
-
Fetch the job context.
- fetchCheckpointInfo(String, String, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- fetchCheckpointInfo(String, String, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- fetchCheckpointStats(String, Long, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- fetchCheckpointStats(String, Long, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- FETCHER_FLINK_CLUSTER_HOST - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- FETCHER_FLINK_CLUSTER_PORT - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- fetchSavepointInfo(String, String, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- fetchSavepointInfo(String, String, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- FIELD_NAME_ACC_BACK_PRESSURE - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_ACC_BUSY - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_ACC_IDLE - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_BYTES_READ - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_BYTES_WRITTEN - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_FLINK_REVISION - Static variable in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfiguration
- FIELD_NAME_FLINK_VERSION - Static variable in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfiguration
- FIELD_NAME_IS_STOPPABLE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_STATUS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_VERTEX_DURATION - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_END_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_INFOS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JOB_VERTEX_METRICS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_NAME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTEX_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_JOB_VERTICES_PER_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_JSON_PLAN - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_NOW - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_PARALLELISM - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_RECORDS_READ - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_RECORDS_WRITTEN - Static variable in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- FIELD_NAME_SLOT_SHARING_GROUP_ID - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_START_TIME - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_TASKS_PER_STATE - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- FIELD_NAME_TIMESTAMPS - Static variable in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- FIELD_NAME_TOTAL_CPU - Static variable in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- FIELD_NAME_TOTAL_MEMORY - Static variable in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- FileSystemBasedArtifactFetcher - Class in org.apache.flink.kubernetes.operator.artifact
-
Leverage the flink filesystem plugin to fetch the artifact.
- FileSystemBasedArtifactFetcher() - Constructor for class org.apache.flink.kubernetes.operator.artifact.FileSystemBasedArtifactFetcher
- FileSystemWatchService - Class in org.apache.flink.kubernetes.operator.fs
-
Service which is able to watch local filesystem directories.
- FileSystemWatchService(String) - Constructor for class org.apache.flink.kubernetes.operator.fs.FileSystemWatchService
- findAll(Collection<String>) - Method in enum org.apache.flink.autoscaler.metrics.FlinkMetric
- findAny(Collection<String>) - Method in enum org.apache.flink.autoscaler.metrics.FlinkMetric
- findExistingEvent(KubernetesClient, HasMetadata, String) - Static method in class org.apache.flink.kubernetes.operator.utils.EventUtils
- FINISHED_METRICS - Static variable in enum org.apache.flink.autoscaler.metrics.FlinkMetric
- FINISHED_METRICS - Static variable in class org.apache.flink.autoscaler.topology.IOMetrics
- finishedReconciliation(ResourceID, Map<String, Object>) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- FLINK_CLIENT_TIMEOUT - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- FLINK_DEPLOYMENT - org.apache.flink.kubernetes.operator.api.spec.JobKind
-
FlinkDeployment CR kind.
- FLINK_MEMORY_UTILS - Static variable in class org.apache.flink.autoscaler.tuning.MemoryTuning
- FLINK_MINOR_VERSION_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- FLINK_SESSION_JOB - org.apache.flink.kubernetes.operator.api.spec.JobKind
-
FlinkSessionJob CR kind.
- FLINK_VERSION - Static variable in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- FLINK_VERSION_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- FlinkClusterJobListFetcher - Class in org.apache.flink.autoscaler.standalone.flinkcluster
-
Fetch JobAutoScalerContext based on flink cluster.
- FlinkClusterJobListFetcher(FunctionWithException<Configuration, RestClusterClient<String>, Exception>, Duration) - Constructor for class org.apache.flink.autoscaler.standalone.flinkcluster.FlinkClusterJobListFetcher
- FlinkConfigBuilder - Class in org.apache.flink.kubernetes.operator.config
-
Builder to get effective flink config from
FlinkDeployment
. - FlinkConfigBuilder(String, String, FlinkDeploymentSpec, Configuration) - Constructor for class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- FlinkConfigBuilder(FlinkDeployment, Configuration) - Constructor for class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- FlinkConfigManager - Class in org.apache.flink.kubernetes.operator.config
-
Configuration manager for the Flink operator.
- FlinkConfigManager(Consumer<Set<String>>, boolean) - Constructor for class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
- FlinkConfigManager(Configuration) - Constructor for class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
- FlinkConfigManager(Configuration, Consumer<Set<String>>, boolean) - Constructor for class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
- FlinkDeployment - Class in org.apache.flink.kubernetes.operator.api
-
Custom resource definition that represents both Application and Session deployments.
- FlinkDeployment() - Constructor for class org.apache.flink.kubernetes.operator.api.FlinkDeployment
- FlinkDeploymentContext - Class in org.apache.flink.kubernetes.operator.controller
-
Context for reconciling a Flink resource.
- FlinkDeploymentContext(FlinkDeployment, Context<?>, KubernetesResourceMetricGroup, FlinkConfigManager, Function<FlinkResourceContext<?>, FlinkService>) - Constructor for class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentContext
- FlinkDeploymentController - Class in org.apache.flink.kubernetes.operator.controller
-
Controller that runs the main reconcile loop for Flink deployments.
- FlinkDeploymentController(Set<FlinkResourceValidator>, FlinkResourceContextFactory, ReconcilerFactory, FlinkDeploymentObserverFactory, StatusRecorder<FlinkDeployment, FlinkDeploymentStatus>, EventRecorder, CanaryResourceManager<FlinkDeployment>) - Constructor for class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentController
- FlinkDeploymentList - Class in org.apache.flink.kubernetes.operator.api
-
Multiple Flink deployments.
- FlinkDeploymentList() - Constructor for class org.apache.flink.kubernetes.operator.api.FlinkDeploymentList
- FlinkDeploymentMetrics - Class in org.apache.flink.kubernetes.operator.metrics
-
FlinkDeployment metrics.
- FlinkDeploymentMetrics(KubernetesOperatorMetricGroup, Configuration) - Constructor for class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- FlinkDeploymentObserverFactory - Class in org.apache.flink.kubernetes.operator.observer.deployment
-
The factory to create the observer based on the
FlinkDeployment
mode. - FlinkDeploymentObserverFactory(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.deployment.FlinkDeploymentObserverFactory
- FlinkDeploymentReconciliationStatus - Class in org.apache.flink.kubernetes.operator.api.status
-
Status of the last reconcile step for the flink deployment.
- FlinkDeploymentReconciliationStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.FlinkDeploymentReconciliationStatus
- FlinkDeploymentSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
Spec that describes a Flink application or session cluster deployment.
- FlinkDeploymentSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.FlinkDeploymentSpec
- FlinkDeploymentStatus - Class in org.apache.flink.kubernetes.operator.api.status
-
Last observed status of the Flink deployment.
- FlinkDeploymentStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.FlinkDeploymentStatus
- FlinkMetric - Enum in org.apache.flink.autoscaler.metrics
-
Enum representing the collected Flink metrics for autoscaling.
- FlinkMutator - Class in org.apache.flink.kubernetes.operator.admission.mutator
-
The default mutator.
- FlinkMutator(Set<FlinkResourceMutator>, InformerManager) - Constructor for class org.apache.flink.kubernetes.operator.admission.mutator.FlinkMutator
- FlinkOperator - Class in org.apache.flink.kubernetes.operator
-
Main Class for Flink native k8s operator.
- FlinkOperator(Configuration) - Constructor for class org.apache.flink.kubernetes.operator.FlinkOperator
- FlinkOperatorConfiguration - Class in org.apache.flink.kubernetes.operator.config
-
Configuration class for operator.
- FlinkOperatorConfiguration() - Constructor for class org.apache.flink.kubernetes.operator.config.FlinkOperatorConfiguration
- FlinkOperatorWebhook - Class in org.apache.flink.kubernetes.operator.admission
-
Main Class for Flink native k8s operator.
- FlinkOperatorWebhook() - Constructor for class org.apache.flink.kubernetes.operator.admission.FlinkOperatorWebhook
- FlinkResourceContext<CR extends AbstractFlinkResource<?,?>> - Class in org.apache.flink.kubernetes.operator.controller
-
Context for reconciling a Flink resource.
- FlinkResourceContext() - Constructor for class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
- FlinkResourceContextFactory - Class in org.apache.flink.kubernetes.operator.service
-
Factory for creating the
FlinkResourceContext
. - FlinkResourceContextFactory(FlinkConfigManager, KubernetesOperatorMetricGroup, EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.service.FlinkResourceContextFactory
- FlinkResourceException - Class in org.apache.flink.kubernetes.operator.exception
-
Exception to display as JSON in CRD.
- FlinkResourceException() - Constructor for class org.apache.flink.kubernetes.operator.exception.FlinkResourceException
- FlinkResourceExceptionUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Flink Resource Exception utilities.
- FlinkResourceExceptionUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.FlinkResourceExceptionUtils
- FlinkResourceListener - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Listener interface for Flink resource related events and status changes.
- FlinkResourceListener.FlinkResourceContext<R extends AbstractFlinkResource<?,?>> - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Base for Flink resource Event and StatusUpdate contexts.
- FlinkResourceListener.FlinkStateSnapshotEventContext - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Context for FlinkStateSnapshot Event listener methods.
- FlinkResourceListener.FlinkStateSnapshotResourceContext - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Base for FlinkStateSnapshot Event and StatusUpdate contexts.
- FlinkResourceListener.FlinkStateSnapshotStatusUpdateContext - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Context for FlinkStateSnapshot Status listener methods.
- FlinkResourceListener.ResourceContext - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Base for Resource Event and StatusUpdate contexts.
- FlinkResourceListener.ResourceEventContext<R extends AbstractFlinkResource<?,?>> - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Context for Flink resource Event listener methods.
- FlinkResourceListener.StatusUpdateContext<R extends AbstractFlinkResource<?,S>,S extends CommonStatus<?>> - Interface in org.apache.flink.kubernetes.operator.api.listener
-
Context for Flink resource Status listener methods.
- FlinkResourceMutator - Interface in org.apache.flink.kubernetes.operator.mutator
-
Mutator for Flink Resources.
- FlinkResourceUtils - Class in org.apache.flink.kubernetes.operator.api.utils
-
Utilities for Flink K8S resource.
- FlinkResourceUtils() - Constructor for class org.apache.flink.kubernetes.operator.api.utils.FlinkResourceUtils
- FlinkResourceValidator - Interface in org.apache.flink.kubernetes.operator.validation
-
Validator for different resources.
- FlinkService - Interface in org.apache.flink.kubernetes.operator.service
-
Service for submitting and interacting with Flink clusters and jobs.
- FlinkService.CancelResult - Class in org.apache.flink.kubernetes.operator.service
-
Result of a cancel operation.
- FlinkSessionJob - Class in org.apache.flink.kubernetes.operator.api
-
Custom resource definition that represents a flink session job.
- FlinkSessionJob() - Constructor for class org.apache.flink.kubernetes.operator.api.FlinkSessionJob
- FlinkSessionJobContext - Class in org.apache.flink.kubernetes.operator.controller
-
Context for reconciling a Flink resource.
- FlinkSessionJobContext(FlinkSessionJob, Context<?>, KubernetesResourceMetricGroup, FlinkConfigManager, Function<FlinkResourceContext<?>, FlinkService>) - Constructor for class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobContext
- FlinkSessionJobController - Class in org.apache.flink.kubernetes.operator.controller
-
Controller that runs the main reconcile loop for
FlinkSessionJob
. - FlinkSessionJobController(Set<FlinkResourceValidator>, FlinkResourceContextFactory, Reconciler<FlinkSessionJob>, Observer<FlinkSessionJob>, StatusRecorder<FlinkSessionJob, FlinkSessionJobStatus>, EventRecorder, CanaryResourceManager<FlinkSessionJob>) - Constructor for class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobController
- FlinkSessionJobList - Class in org.apache.flink.kubernetes.operator.api
-
Multiple Flink session jobs.
- FlinkSessionJobList() - Constructor for class org.apache.flink.kubernetes.operator.api.FlinkSessionJobList
- FlinkSessionJobMetrics - Class in org.apache.flink.kubernetes.operator.metrics
-
FlinkSessionJob metrics.
- FlinkSessionJobMetrics(KubernetesOperatorMetricGroup, Configuration) - Constructor for class org.apache.flink.kubernetes.operator.metrics.FlinkSessionJobMetrics
- FlinkSessionJobObserver - Class in org.apache.flink.kubernetes.operator.observer.sessionjob
-
The observer of
FlinkSessionJob
. - FlinkSessionJobObserver(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.sessionjob.FlinkSessionJobObserver
- FlinkSessionJobReconciliationStatus - Class in org.apache.flink.kubernetes.operator.api.status
-
Status of the last reconcile step for the flink sessionjob.
- FlinkSessionJobReconciliationStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.FlinkSessionJobReconciliationStatus
- FlinkSessionJobSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
Spec that describes a Flink session job.
- FlinkSessionJobSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.FlinkSessionJobSpec
- FlinkSessionJobStatus - Class in org.apache.flink.kubernetes.operator.api.status
-
Last observed status of the Flink Session job.
- FlinkSessionJobStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.FlinkSessionJobStatus
- FlinkStandaloneKubeClient - Interface in org.apache.flink.kubernetes.operator.kubeclient
-
Extension of the FlinkKubeClient that is used for Flink standalone deployments.
- FlinkStateSnapshot - Class in org.apache.flink.kubernetes.operator.api
-
Custom resource definition for taking manual savepoints of Flink jobs.
- FlinkStateSnapshot() - Constructor for class org.apache.flink.kubernetes.operator.api.FlinkStateSnapshot
- FlinkStateSnapshotContext - Class in org.apache.flink.kubernetes.operator.controller
-
Context for reconciling a snapshot.
- FlinkStateSnapshotContext() - Constructor for class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotContext
- FlinkStateSnapshotController - Class in org.apache.flink.kubernetes.operator.controller
-
Controller that runs the main reconcile loop for
FlinkStateSnapshot
. - FlinkStateSnapshotController() - Constructor for class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotController
- FlinkStateSnapshotMetrics - Class in org.apache.flink.kubernetes.operator.metrics
-
FlinkStateSnapshot metrics.
- FlinkStateSnapshotMetrics(KubernetesOperatorMetricGroup, Configuration) - Constructor for class org.apache.flink.kubernetes.operator.metrics.FlinkStateSnapshotMetrics
- FlinkStateSnapshotSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
Spec that describes a FlinkStateSnapshot.
- FlinkStateSnapshotSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.FlinkStateSnapshotSpec
- FlinkStateSnapshotStatus - Class in org.apache.flink.kubernetes.operator.api.status
-
Last observed status of the Flink state snapshot.
- FlinkStateSnapshotStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus
- FlinkStateSnapshotStatus.State - Enum in org.apache.flink.kubernetes.operator.api.status
-
Describes state of a snapshot.
- FlinkStateSnapshotUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Utilities class for FlinkStateSnapshot resources.
- FlinkStateSnapshotUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
- FlinkUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Flink Utility methods used by the operator.
- FlinkUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- FlinkValidator - Class in org.apache.flink.kubernetes.operator.admission
-
Validator for FlinkDeployment creation and updates.
- FlinkValidator(Set<FlinkResourceValidator>, InformerManager) - Constructor for class org.apache.flink.kubernetes.operator.admission.FlinkValidator
- FlinkVersion - Enum in org.apache.flink.kubernetes.operator.api.spec
-
Enumeration for supported Flink versions.
- flinkVersionChanged(SPEC, SPEC) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- flush() - Method in class org.apache.flink.autoscaler.jdbc.state.JobStateView
- flush(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- flush(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
-
Flushing is needed because we do not persist data for all store methods until this method is called.
- flush(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- flush(String) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateStore
- flush(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- flush(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- format(Event, String) - Static method in class org.apache.flink.kubernetes.operator.listener.AuditUtils
- formatErrorMessage(Long) - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- formatErrorMessage(Long) - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- formatErrorMessage(Long) - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- formatScope(String, String, String) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorScopeFormat
- formatScope(String, String, String, String, String) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceScopeFormat
- formatScope(String, String, String, String, String, String) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceScopeFormat
- FORWARD - org.apache.flink.autoscaler.topology.ShipStrategy
- from - Variable in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics.Transition
- from(Collection<DiffType>) - Static method in enum org.apache.flink.kubernetes.operator.api.diff.DiffType
-
Aggregate a collection of
DiffType
s into the type that minimally subsumes all the diffs. - from(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.reconciler.ReconciliationMetadata
- from(IOMetricsInfo) - Static method in class org.apache.flink.autoscaler.topology.IOMetrics
- fromConfig(Configuration) - Static method in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorScopeFormat
- fromConfig(Configuration) - Static method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceScopeFormat
- fromConfig(Configuration) - Static method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceScopeFormat
- fromConfig(FlinkConfigManager) - Static method in class org.apache.flink.kubernetes.operator.health.OperatorHealthService
- fromConfiguration(Configuration) - Static method in class org.apache.flink.kubernetes.operator.config.FlinkOperatorConfiguration
- fromFlinkResource(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.spec.JobReference
- fromHexString(String) - Static method in class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIdConverter
- fromJsonPlan(String, Map<JobVertexID, SlotSharingGroupId>, Map<JobVertexID, Integer>, Map<JobVertexID, IOMetrics>, Set<JobVertexID>) - Static method in class org.apache.flink.autoscaler.topology.JobTopology
- fromRuntimeInfo(RuntimeInfo) - Static method in class org.apache.flink.kubernetes.operator.health.InformerHealthSummary
- FULL - org.apache.flink.kubernetes.operator.api.status.CheckpointType
G
- GC_PRESSURE - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Maximum GC pressure across taskmanagers.
- GC_PRESSURE_MESSAGE - Static variable in class org.apache.flink.autoscaler.ScalingExecutor
- GC_PRESSURE_THRESHOLD - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- GENERATED_FILE_PREFIX - Static variable in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- generateEventName(HasMetadata, EventRecorder.Type, String, String, EventRecorder.Component) - Static method in class org.apache.flink.kubernetes.operator.utils.EventUtils
- generateJarDir(ObjectMeta, FlinkSessionJobSpec) - Method in class org.apache.flink.kubernetes.operator.artifact.ArtifactManager
- get(String) - Static method in class org.apache.flink.kubernetes.operator.utils.EnvUtils
-
Get the value provided by environments.
- get(StateType) - Method in class org.apache.flink.autoscaler.jdbc.state.JobStateView
- get(JobVertexID) - Method in class org.apache.flink.autoscaler.topology.JobTopology
- get(AggregatedMetric) - Method in enum org.apache.flink.autoscaler.metrics.MetricAggregator
- getAccumulatedBackpressured() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getAccumulatedBusy() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getAccumulatedIdle() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getAllowNonRestoredState() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- getAnnotations() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getAvailableVertexMetricNames() - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- getAverage(ScalingMetric, JobVertexID, SortedMap<Instant, CollectedMetrics>) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
- getAverage(ScalingMetric, JobVertexID, SortedMap<Instant, CollectedMetrics>, int) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
- getAvg() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getBytesRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getBytesWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getCache() - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- getCache() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
- getCheckpointInfo(JobID, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getCheckpointInfo(JobID, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getCheckpointInfo(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.FlinkResourceUtils
- getClearedStatesAfterTransition(ResourceLifecycleState) - Method in enum org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- getClusterClient(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getClusterClient(Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getClusterDescription() - Method in class org.apache.flink.kubernetes.operator.standalone.KubernetesStandaloneClusterDescriptor
- getClusterInfo(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getClusterInfo(Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getCollectedMetrics(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- getCollectedMetrics(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- getCollectedMetrics(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- getCollectedMetrics(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- getCommonLabels() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- getCommonLabels(String) - Static method in class org.apache.flink.kubernetes.operator.utils.StandaloneKubernetesUtils
- getConfigChanges(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- getConfigChanges(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- getConfigChanges(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- getConfigChanges(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- getConnection(Configuration) - Static method in class org.apache.flink.autoscaler.standalone.utils.HikariJDBCUtil
- getCount() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedCounter
- getCount() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedHistogram
- getCount() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedMeterView
- getCpuLimitFactor() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getCurrentInstant() - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcEventInteractor
- getCurrentState() - Method in class org.apache.flink.kubernetes.operator.metrics.lifecycle.ResourceLifecycleMetricTracker
- getDataReadOnly() - Method in class org.apache.flink.autoscaler.jdbc.state.JobStateView
- getDefaultConfig() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
- getDefaultConfig(String, FlinkVersion) - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
-
Get the base configuration for the given namespace and flink version combination.
- getDelayedScaleDown(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- getDelayedScaleDown(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- getDelayedScaleDown(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- getDelayedScaleDown(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- getDeployConfig(ObjectMeta, FlinkDeploymentSpec) - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
-
Get deployment configuration that will be passed to the Flink Cluster clients during cluster submission.
- getDeployConfig(AbstractFlinkSpec) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentContext
- getDeployConfig(AbstractFlinkSpec) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
-
Get Flink configuration object for deploying the given spec using
AbstractFlinkResourceReconciler.deploy(org.apache.flink.kubernetes.operator.controller.FlinkResourceContext<CR>, SPEC, org.apache.flink.configuration.Configuration, java.util.Optional<java.lang.String>, boolean)
. - getDeployConfig(AbstractFlinkSpec) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobContext
- getDeployedSpec(AbstractFlinkResource<SPEC, ?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- getDeploymentInformerEventSource(EventSourceContext<FlinkDeployment>) - Static method in class org.apache.flink.kubernetes.operator.utils.EventSourceUtils
- getDeploymentMode() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentContext
- getDeploymentMode() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
- getDeploymentMode() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobContext
- getDeploymentMode(FlinkDeployment) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.KubernetesDeploymentMode
- getDeploymentMode(FlinkDeploymentSpec) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.KubernetesDeploymentMode
- getDescription() - Method in enum org.apache.flink.autoscaler.standalone.AutoscalerEventHandlerFactory.EventHandlerType
- getDescription() - Method in enum org.apache.flink.autoscaler.standalone.AutoscalerStateStoreFactory.StateStoreType
- getDescription() - Method in enum org.apache.flink.kubernetes.operator.api.status.CheckpointType
- getDescription() - Method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getDescription() - Method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getDuration() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getEndTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getEnvironments() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getEvent() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.FlinkStateSnapshotEventContext
- getEvent() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.ResourceEventContext
- getExecutionState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getFlinkDepInformer(String) - Method in class org.apache.flink.kubernetes.operator.admission.informer.InformerManager
- getFlinkDeploymentInformerEventSource(EventSourceContext<FlinkSessionJob>) - Static method in class org.apache.flink.kubernetes.operator.utils.EventSourceUtils
- getFlinkResource() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.FlinkResourceContext
- getFlinkService() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
-
Get the
FlinkService
implementation for the current resource. - getFlinkService(FlinkResourceContext<?>) - Method in class org.apache.flink.kubernetes.operator.service.FlinkResourceContextFactory
- getFlinkSessionJobInformer(String) - Method in class org.apache.flink.kubernetes.operator.admission.informer.InformerManager
- getFlinkStateSnapshotContext(FlinkStateSnapshot, Context<FlinkStateSnapshot>) - Method in class org.apache.flink.kubernetes.operator.service.FlinkResourceContextFactory
- getFlinkStateSnapshotInformerEventSources(EventSourceContext<FlinkStateSnapshot>) - Static method in class org.apache.flink.kubernetes.operator.utils.EventSourceUtils
- getFlinkStateSnapshotName(SnapshotType, SnapshotTriggerType, AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Return a generated name for a
FlinkStateSnapshot
to be created. - getFlinkStateSnapshotsSupplier(FlinkResourceContext<?>) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Returns a supplier of all relevant FlinkStateSnapshot resources for a given Flink resource.
- getFlinkVersion() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentContext
- getFlinkVersion() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
- getFlinkVersion() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobContext
- getFree() - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesResource
- getGroupName(CharacterFilter) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceMetricGroup
- getGroupName(CharacterFilter) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceMetricGroup
- getHistories() - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- getHttpMethod() - Method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getHttpMethod() - Method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getId() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getIdentifier() - Method in enum org.apache.flink.autoscaler.jdbc.state.StateType
- getIngressUrl(String, String, String) - Static method in class org.apache.flink.kubernetes.operator.utils.IngressUtils
- getInProgressCheckpoint() - Method in class org.apache.flink.kubernetes.operator.service.CheckpointHistoryWrapper
- getInstance() - Static method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getInstance() - Static method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getJmPodList(String, String) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getJmPodList(String, String) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- getJmPodList(String, String) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- getJmPodList(FlinkDeployment, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getJmPodList(FlinkDeployment, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getJobAutoScalerContext() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
- getJobDetailsInfo(JobAutoScalerContext<KEY>, Duration) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- getJobId() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJobManagerDeploymentName(String) - Static method in class org.apache.flink.kubernetes.operator.utils.StandaloneKubernetesUtils
- getJobManagerSelectors(String) - Static method in class org.apache.flink.kubernetes.operator.utils.StandaloneKubernetesUtils
- getJobRunningTs(JobDetailsInfo) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- getJobSpec(AbstractFlinkResource<? extends AbstractFlinkSpec, ? extends CommonStatus<?>>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.FlinkResourceUtils
- getJobSpecArgs() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- getJobStatus() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJobStatus(Configuration, JobID) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getJobStatus(Configuration, JobID) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getJobStatus(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.FlinkResourceUtils
- getJobTopology(Context, AutoScalerStateStore<KEY, Context>, JobDetailsInfo) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- getJobTopology(JobDetailsInfo) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- getJobUpgrade(FlinkResourceContext<CR>, Configuration) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- getJobUpgrade(FlinkResourceContext<FlinkDeployment>, Configuration) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.ApplicationReconciler
- getJobVertexID() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getJobVertexInfos() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJobVertexMetrics() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getJobVerticesPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getJsonPlan() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getKubernetesClient() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.ResourceContext
- getKubernetesClient() - Method in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesJobAutoScalerContext
- getKubernetesClient() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
-
Get KubernetesClient available from JOSDK Context.
- getKubernetesClient() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotContext
-
Get KubernetesClient available from JOSDK Context.
- getKubernetesClient() - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getKubernetesClient() - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getKubernetesClient(FlinkOperatorConfiguration, MetricGroup) - Static method in class org.apache.flink.kubernetes.operator.utils.KubernetesClientUtils
- getKubernetesClient(FlinkOperatorConfiguration, MetricGroup, Config) - Static method in class org.apache.flink.kubernetes.operator.utils.KubernetesClientUtils
- getLabels() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- getLabels() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getLastCheckpoint(JobID, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getLastCheckpoint(JobID, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getLastPeriodicTriggerInstant(AbstractFlinkResource<?, ?>, SnapshotType, Supplier<Set<FlinkStateSnapshot>>) - Method in class org.apache.flink.kubernetes.operator.reconciler.SnapshotTriggerTimestampStore
-
Returns the time a periodic snapshot was last triggered for this resource.
- getLastPeriodicTriggerTimestamp() - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- getLastPeriodicTriggerTimestamp() - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- getLastPeriodicTriggerTimestamp() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- getLastSnapshot() - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- getLastSnapshot() - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- getLastSnapshot() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- getLastSnapshotStatus(AbstractFlinkResource<?, ?>, SnapshotType) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
- getLastTriggerNonce() - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- getLastTriggerNonce() - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- getLastTriggerNonce() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- getLastTriggerType() - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- getLastTriggerType() - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- getLastTriggerType() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- getLastValidClusterHealthInfo(Map<String, String>) - Static method in class org.apache.flink.kubernetes.operator.observer.ClusterHealthEvaluator
- getLatestCompletedCheckpoint() - Method in class org.apache.flink.kubernetes.operator.service.CheckpointHistoryWrapper
- getLatestScalingRecordEntry() - Method in class org.apache.flink.autoscaler.ScalingTracking
- getLifecycleState() - Method in class org.apache.flink.kubernetes.operator.api.status.CommonStatus
- getLifecycleTrackers() - Method in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics
- getMainClass() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- getMax() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getMaxParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getMaxParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getMaxRestartTimeOrDefault(Configuration) - Method in class org.apache.flink.autoscaler.ScalingTracking
-
Retrieves the maximum restart time based on the provided configuration and scaling records.
- getMemoryLimitFactor() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getMetricGroup() - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- getMetrics(Configuration, String, List<String>) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getMetrics(Configuration, String, List<String>) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- getMetricWindowSize(Configuration) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- getMin() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getMode(FlinkDeployment) - Static method in enum org.apache.flink.kubernetes.operator.config.Mode
-
Return the mode of the given FlinkDeployment for Observer and Reconciler.
- getName() - Method in class org.apache.flink.kubernetes.operator.api.docs.CrdReferenceDoclet
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getName() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getNewStatus() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.FlinkStateSnapshotStatusUpdateContext
- getNewStatus() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.StatusUpdateContext
- getNodeSelector() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getNow() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getNumBalancedCount() - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- getNumberOfActiveCanaries() - Method in class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- getNumDiffs() - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.DiffResult
- getNumErrorsCount() - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- getNumScalingsCount() - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- getNumTaskManagers(Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- getNumTaskManagers(Configuration, int) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- getObserveConfig() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
-
Get the config that is currently deployed for the resource spec.
- getObserveConfig(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
-
Get the observe configuration that can be used to interact with already submitted clusters through the Flink rest clients.
- getOperator() - Method in class org.apache.flink.kubernetes.operator.FlinkOperator
- getOperatorConfig() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkResourceContext
- getOperatorConfiguration() - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
- getOperatorConfiguration(String, FlinkVersion) - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
-
Get the operator configuration for the given namespace and flink version combination.
- getOrCreate(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.FlinkDeploymentObserverFactory
- getOrCreate(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.ReconcilerFactory
- getOrDefault(String, String) - Static method in class org.apache.flink.kubernetes.operator.utils.EnvUtils
-
Get the value or default value provided by environments.
- getOwnerReference() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getParallelism() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getParallelismHashCode(Map<JobVertexID, ScalingSummary>) - Static method in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- getParallelismOverrides(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- getParallelismOverrides(Context) - Method in class org.apache.flink.autoscaler.JobAutoScalerImpl
- getParallelismOverrides(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- getParallelismOverrides(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- getParallelismOverrides(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- getPodTemplateFilePath() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getPreviousStatus() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.FlinkStateSnapshotStatusUpdateContext
- getPreviousStatus() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.StatusUpdateContext
- getRate() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedMeterView
- getRate(ScalingMetric, JobVertexID, SortedMap<Instant, CollectedMetrics>) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
-
Compute per second rate for the given accumulated metric over the metric window.
- getReason() - Method in exception org.apache.flink.kubernetes.operator.exception.DeploymentFailedException
- getReason() - Method in exception org.apache.flink.kubernetes.operator.exception.UpgradeFailureException
- getReconciledJobSpec(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.FlinkResourceUtils
- getReconciledJobState(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.FlinkResourceUtils
- getReconciliationStatus() - Method in class org.apache.flink.kubernetes.operator.api.status.CommonStatus
-
Current reconciliation status of this resource.
- getRecordsRead() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getRecordsWritten() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- getRegisteredMetrics() - Method in class org.apache.flink.kubernetes.operator.metrics.MetricManager
- getRemaining() - Method in class org.apache.flink.autoscaler.tuning.MemoryBudget
- getReplicas() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getRequestClass() - Method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getRequestClass() - Method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getRequired(String) - Static method in class org.apache.flink.kubernetes.operator.utils.EnvUtils
-
Get the value provided by environments.
- getResource() - Method in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesJobAutoScalerContext
- getResourceContext(CR, Context) - Method in class org.apache.flink.kubernetes.operator.service.FlinkResourceContextFactory
- getResponseClass() - Method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getResponseClass() - Method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getResponseStatusCode() - Method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getResponseStatusCode() - Method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getRestClient(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getRestClusterClient() - Method in class org.apache.flink.autoscaler.JobAutoScalerContext
- getRPCPort() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getSavepointInfo(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.FlinkResourceUtils
- getSavepointPath() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- getSavepointPath() - Method in class org.apache.flink.kubernetes.operator.service.FlinkService.CancelResult
- getScalingHistory(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- getScalingHistory(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- getScalingHistory(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- getScalingHistory(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- getScalingTracking(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- getScalingTracking(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- getScalingTracking(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- getScalingTracking(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- getSecondaryResource() - Method in class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotContext
- getSelectors() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- getSelectors() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getSerializedState(String, StateType) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateStore
- getSerializedState(KubernetesJobAutoScalerContext, String) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- getServiceAccount() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getSessionJobConfig(String, FlinkDeployment, FlinkSessionJobSpec) - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
-
Get configuration for interacting with session jobs.
- getSessionJobInformerEventSource(EventSourceContext<FlinkDeployment>) - Static method in class org.apache.flink.kubernetes.operator.utils.EventSourceUtils
- getSkew() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getSlotSharingGroupId() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getSnapshotJobReferenceResourceId(FlinkStateSnapshot) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Extracts the namespace of the job reference from a snapshot resource.
- getSnapshotLabels(FlinkStateSnapshot, Optional<AbstractFlinkResource<?, ?>>) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Creates a map of labels that can be applied to a snapshot resource based on its current spec and status.
- getSnapshotTriggerType(FlinkStateSnapshot) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Extracts snapshot trigger type from a snapshot resource.
- getSocketAddress(RestClusterClient<String>) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- getSpecClass() - Method in class org.apache.flink.kubernetes.operator.api.status.FlinkDeploymentReconciliationStatus
- getSpecClass() - Method in class org.apache.flink.kubernetes.operator.api.status.FlinkSessionJobReconciliationStatus
- getSpecClass() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getStartTime() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getStateSnapshot() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.FlinkStateSnapshotResourceContext
- getStateSnapshotForFlinkResourceInformerEventSource(EventSourceContext<T>) - Static method in class org.apache.flink.kubernetes.operator.utils.EventSourceUtils
- getStateTimeHistos() - Method in class org.apache.flink.kubernetes.operator.metrics.lifecycle.ResourceLifecycleMetricTracker
- getStatistics() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedHistogram
- getSubstringWithMaxLength(String, int) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkResourceExceptionUtils
- getSum() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- getSupportedOptions() - Method in class org.apache.flink.kubernetes.operator.api.docs.CrdReferenceDoclet
- getSupportedSourceVersion() - Method in class org.apache.flink.kubernetes.operator.api.docs.CrdReferenceDoclet
- getTargetProcessingCapacity(Map<ScalingMetric, EvaluatedScalingMetric>, Configuration, double, boolean, Duration) - Static method in class org.apache.flink.autoscaler.utils.AutoScalerUtils
- getTargetRestEndpointURL() - Method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getTargetRestEndpointURL() - Method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getTaskManagerCpu() - Method in class org.apache.flink.autoscaler.JobAutoScalerContext
-
Retrieve the currently configured TaskManager CPU.
- getTaskManagerCpu() - Method in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesJobAutoScalerContext
- getTaskManagerCPU() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getTaskManagerDeploymentName(String) - Static method in class org.apache.flink.kubernetes.operator.utils.StandaloneKubernetesUtils
- getTaskManagerMemory() - Method in class org.apache.flink.autoscaler.JobAutoScalerContext
-
Retrieve the currently configured TaskManager memory.
- getTaskManagerMemoryMB() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getTaskManagerSelectors(String) - Static method in class org.apache.flink.kubernetes.operator.utils.StandaloneKubernetesUtils
- getTasksPerState() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- getTimestamp() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.FlinkStateSnapshotEventContext
- getTimestamp() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.ResourceContext
- getTimestamp() - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener.ResourceEventContext
- getTimeStamp() - Method in interface org.apache.flink.kubernetes.operator.api.status.Snapshot
- getTimestamps() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- getTolerations() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- getTotalMemory(Configuration, JobAutoScalerContext<?>) - Static method in class org.apache.flink.autoscaler.tuning.MemoryTuning
- getTransitionHistos() - Method in class org.apache.flink.kubernetes.operator.metrics.lifecycle.ResourceLifecycleMetricTracker
- getTriggerId() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- getTriggerTimestamp() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- getTriggerType() - Method in interface org.apache.flink.kubernetes.operator.api.status.Snapshot
- getTriggerType() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- getTrimmedScalingHistory(AutoScalerStateStore<KEY, Context>, Context, Instant) - Static method in class org.apache.flink.autoscaler.metrics.ScalingHistoryUtils
- getTrimmedScalingTracking(AutoScalerStateStore<KEY, Context>, Context, Instant) - Static method in class org.apache.flink.autoscaler.metrics.ScalingHistoryUtils
- getUnresolvedMessageParameters() - Method in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- getUnresolvedMessageParameters() - Method in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- getUpgradeModeBasedOnStateAge(FlinkResourceContext<CR>, Configuration, boolean) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- getUpgradeTargetGeneration(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
Get spec generation for the current in progress upgrade.
- getUsed() - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesResource
- getValueWithThreshold(Configuration, ConfigOption<T>, T) - Static method in class org.apache.flink.kubernetes.operator.utils.ConfigOptionUtils
-
Gets the value of
ConfigOption
with threshold. - getVertexResources(RestClusterClient<String>, AbstractFlinkResource<?, ?>) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- GLOBAL - org.apache.flink.autoscaler.topology.ShipStrategy
- gracePeriodEnded(Duration, SnapshotInfo) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
H
- handle(AdmissionRequest) - Method in class org.apache.flink.kubernetes.operator.admission.mutator.DefaultRequestMutator
- handleCanaryResourceDeletion(CR) - Method in class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- handleCanaryResourceReconciliation(CR, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- handleEvent(Context, AutoScalerEventHandler.Type, String, String, String, Duration) - Method in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
-
Handle the event.
- handleEvent(Context, AutoScalerEventHandler.Type, String, String, String, Duration) - Method in class org.apache.flink.autoscaler.event.LoggingEventHandler
- handleEvent(Context, AutoScalerEventHandler.Type, String, String, String, Duration) - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcAutoScalerEventHandler
- handleEvent(KubernetesJobAutoScalerContext, AutoScalerEventHandler.Type, String, String, String, Duration) - Method in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesAutoScalerEventHandler
- handleException(Context, String, Throwable) - Method in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
-
Handle exception, and the exception event is warning type and don't deduplicate by default.
- handleScalingEvent(Context, Map<JobVertexID, ScalingSummary>, String, Duration) - Method in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
-
Handle scaling reports.
- handleScalingEvent(Context, Map<JobVertexID, ScalingSummary>, String, Duration) - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcAutoScalerEventHandler
- handleScalingEvent(KubernetesJobAutoScalerContext, Map<JobVertexID, ScalingSummary>, String, Duration) - Method in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesAutoScalerEventHandler
- HASH - org.apache.flink.autoscaler.topology.ShipStrategy
- hashCode() - Method in class org.apache.flink.autoscaler.JobVertexScaler.ParallelismChange
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- hashCode() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- HealthProbe - Enum in org.apache.flink.kubernetes.operator.health
-
Flink operator health probe.
- HEAP_MAX_USAGE_RATIO - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Percentage of max heap used (between 0 and 1).
- HEAP_MEMORY_MAX - org.apache.flink.autoscaler.metrics.FlinkMetric
- HEAP_MEMORY_USED - org.apache.flink.autoscaler.metrics.FlinkMetric
- HEAP_MEMORY_USED - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Measured max used heap size in bytes.
- HEAP_USAGE_MESSAGE - Static variable in class org.apache.flink.autoscaler.ScalingExecutor
- HEAP_USAGE_THRESHOLD - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- HikariJDBCUtil - Class in org.apache.flink.autoscaler.standalone.utils
-
Hikari JDBC common util.
- HikariJDBCUtil() - Constructor for class org.apache.flink.autoscaler.standalone.utils.HikariJDBCUtil
- HISTO - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- hostname - Variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- HTTP_REQUEST_FAILED_GROUP - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HTTP_REQUEST_GROUP - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HTTP_RESPONSE_1XX - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HTTP_RESPONSE_2XX - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HTTP_RESPONSE_3XX - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HTTP_RESPONSE_4XX - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HTTP_RESPONSE_5XX - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HTTP_RESPONSE_GROUP - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- HttpArtifactFetcher - Class in org.apache.flink.kubernetes.operator.artifact
-
Download the jar from the http resource.
- HttpArtifactFetcher() - Constructor for class org.apache.flink.kubernetes.operator.artifact.HttpArtifactFetcher
- HttpBootstrap - Class in org.apache.flink.kubernetes.operator.health
-
Class for serving HTTP requests for the health probe.
- HttpBootstrap(HealthProbe, int) - Constructor for class org.apache.flink.kubernetes.operator.health.HttpBootstrap
I
- IGNORE - org.apache.flink.kubernetes.operator.api.diff.DiffType
-
Ignorable spec change.
- IN_PROGRESS - org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus.State
-
Snapshot in progress.
- inc() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedCounter
- inc(long) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedCounter
- INCREMENTAL - org.apache.flink.kubernetes.operator.api.status.CheckpointType
- incrementBalanced() - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- incrementError() - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- incrementScaling() - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- INEFFECTIVE_MESSAGE_FORMAT - Static variable in class org.apache.flink.autoscaler.JobVertexScaler
- INEFFECTIVE_SCALING - Static variable in class org.apache.flink.autoscaler.JobVertexScaler
- IneffectiveScaling - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- inExcludedPeriods(Configuration, Instant) - Static method in class org.apache.flink.autoscaler.utils.CalendarUtils
- InformerHealthSummary - Class in org.apache.flink.kubernetes.operator.health
-
Operator informer health summary.
- InformerHealthSummary() - Constructor for class org.apache.flink.kubernetes.operator.health.InformerHealthSummary
- InformerIdentifier - Class in org.apache.flink.kubernetes.operator.health
-
Operator informer identifier.
- InformerIdentifier() - Constructor for class org.apache.flink.kubernetes.operator.health.InformerIdentifier
- InformerManager - Class in org.apache.flink.kubernetes.operator.admission.informer
-
The manager of the informers.
- InformerManager(KubernetesClient) - Constructor for class org.apache.flink.kubernetes.operator.admission.informer.InformerManager
- ingressInNetworkingV1(KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.utils.IngressUtils
- IngressSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
Ingress spec.
- IngressSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.IngressSpec
- IngressUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Ingress utilities.
- IngressUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.IngressUtils
- init(Locale, Reporter) - Method in class org.apache.flink.kubernetes.operator.api.docs.CrdReferenceDoclet
- initOperatorMetrics(Configuration) - Static method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils
- initRecommendedParallelism(Map<JobVertexID, Map<ScalingMetric, EvaluatedScalingMetric>>) - Static method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- initSpec() - Method in class org.apache.flink.kubernetes.operator.api.FlinkDeployment
- initSpec() - Method in class org.apache.flink.kubernetes.operator.api.FlinkSessionJob
- initSpec() - Method in class org.apache.flink.kubernetes.operator.api.FlinkStateSnapshot
- InitStandaloneTaskManagerDecorator - Class in org.apache.flink.kubernetes.operator.kubeclient.decorators
-
An initializer for the TaskManager
FlinkPod
in standalone mode. - InitStandaloneTaskManagerDecorator(StandaloneKubernetesTaskManagerParameters) - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.decorators.InitStandaloneTaskManagerDecorator
- initStatus() - Method in class org.apache.flink.kubernetes.operator.api.FlinkDeployment
- initStatus() - Method in class org.apache.flink.kubernetes.operator.api.FlinkSessionJob
- InMemoryAutoScalerStateStore<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler.state
-
State store based on the Java Heap, the state will be discarded after process restarts.
- InMemoryAutoScalerStateStore() - Constructor for class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- INSTANCE - org.apache.flink.kubernetes.operator.health.HealthProbe
- INSTANCE - Static variable in class org.apache.flink.kubernetes.operator.artifact.FileSystemBasedArtifactFetcher
- INSTANCE - Static variable in class org.apache.flink.kubernetes.operator.artifact.HttpArtifactFetcher
- INSTANCE - Static variable in class org.apache.flink.kubernetes.operator.service.CustomDashboardConfigurationHeaders
- INTERNAL_METADATA_JSON_KEY - Static variable in class org.apache.flink.kubernetes.operator.api.utils.SpecUtils
- IOMetrics - Class in org.apache.flink.autoscaler.topology
-
Vertex io metrics.
- IOMetrics() - Constructor for class org.apache.flink.autoscaler.topology.IOMetrics
- IOMetricsInfo - Class in org.apache.flink.runtime.rest.messages.job.metrics
-
IO metrics information.
- IOMetricsInfo(long, boolean, long, boolean, long, boolean, long, boolean, Long, Long, Double) - Constructor for class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isApplicationCluster() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- isBeforeFirstDeployment() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- isBytesReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isBytesWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isCanaryResource(HasMetadata) - Static method in class org.apache.flink.kubernetes.operator.health.CanaryResourceManager
- isCheckpoint() - Method in class org.apache.flink.kubernetes.operator.api.spec.FlinkStateSnapshotSpec
- isClient() - Method in class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- isCrdInstalled(Class<? extends HasMetadata>) - Static method in class org.apache.flink.kubernetes.operator.utils.KubernetesClientUtils
-
Checks if the class for a Custom Resource is installed in the current Kubernetes cluster.
- isEqualOrNewer(FlinkVersion) - Method in enum org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
- isHAEnabled() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- isHaMetadataAvailable(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- isHaMetadataAvailable(Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- isHealthy() - Method in enum org.apache.flink.kubernetes.operator.health.HealthProbe
- isInternalServiceEnabled() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- isJmDeploymentReady(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- isJobCancellable(CommonStatus<?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- isJobCancelled(CommonStatus<?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- isJobCancelling(CommonStatus<?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- isJobInTerminalState(CommonStatus<?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- isJobManagerPortReady(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- isJobManagerPortReady(Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- isJobMissing(Exception) - Static method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- isJobRunning(CommonStatus<?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- isJobTerminated(Exception) - Static method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- isKubernetesHAActivated(Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- isKubernetesHaMetadataAvailable(Configuration, KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- isKubernetesHaMetadataAvailableWithCheckpoint(Configuration, KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- isLastReconciledSpecStable() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- isPipelineClasspathDefined() - Method in class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- isProcessingBacklog(JobTopology, SortedMap<Instant, CollectedMetrics>, Configuration) - Static method in class org.apache.flink.autoscaler.ScalingMetricEvaluator
- isRecordsReadComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isRecordsWrittenComplete() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.IOMetricsInfo
- isResourceReadyToBeObserved(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.observer.AbstractFlinkResourceObserver
-
Check whether the resource should be observed.
- isResourceReadyToBeObserved(FlinkResourceContext<FlinkSessionJob>) - Method in class org.apache.flink.kubernetes.operator.observer.sessionjob.FlinkSessionJobObserver
- isSavepoint() - Method in class org.apache.flink.kubernetes.operator.api.spec.FlinkStateSnapshotSpec
- isScaledUp() - Method in class org.apache.flink.autoscaler.ScalingSummary
- isSnapshotResourceEnabled(FlinkOperatorConfiguration, Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Based on job configuration and operator configuration, decide if
FlinkStateSnapshot
resources should be used or not. - isSnapshotTriggeringSupported(Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
- isSource(JobVertexID) - Method in class org.apache.flink.autoscaler.topology.JobTopology
- isStoppable() - Method in class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- isSupported(FlinkVersion) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
- isSuspendedJob(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- isValid(ClusterHealthInfo) - Static method in class org.apache.flink.kubernetes.operator.health.ClusterHealthInfo
- isZookeeperHAActivated(Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- isZookeeperHaMetadataAvailable(Configuration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
J
- JAR_ARTIFACT_HTTP_HEADER - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- JDBC - org.apache.flink.autoscaler.standalone.AutoscalerEventHandlerFactory.EventHandlerType
- JDBC - org.apache.flink.autoscaler.standalone.AutoscalerStateStoreFactory.StateStoreType
- JDBC_EVENT_HANDLER_TTL - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- JDBC_PASSWORD_ENV_VARIABLE - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- JDBC_URL - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- JDBC_URL_REQUIRED_HINT - Static variable in class org.apache.flink.autoscaler.standalone.utils.HikariJDBCUtil
- JDBC_USERNAME - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- JdbcAutoScalerEventHandler<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler.jdbc.event
-
The event handler which persists its event in JDBC related database.
- JdbcAutoScalerEventHandler(JdbcEventInteractor, Duration) - Constructor for class org.apache.flink.autoscaler.jdbc.event.JdbcAutoScalerEventHandler
- JdbcAutoScalerStateStore<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler.jdbc.state
-
The state store which persists its state in JDBC related database.
- JdbcAutoScalerStateStore(JdbcStateStore) - Constructor for class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- JdbcEventInteractor - Class in org.apache.flink.autoscaler.jdbc.event
-
Responsible for interacting with the database.
- JdbcEventInteractor(Connection) - Constructor for class org.apache.flink.autoscaler.jdbc.event.JdbcEventInteractor
- JdbcStateInteractor - Class in org.apache.flink.autoscaler.jdbc.state
-
Responsible for interacting with the database.
- JdbcStateInteractor(Connection) - Constructor for class org.apache.flink.autoscaler.jdbc.state.JdbcStateInteractor
- JdbcStateStore - Class in org.apache.flink.autoscaler.jdbc.state
-
The jdbc state store.
- JdbcStateStore(JdbcStateInteractor) - Constructor for class org.apache.flink.autoscaler.jdbc.state.JdbcStateStore
- jmPodNeverStarted(Context<?>) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
-
Check if the jobmanager pod has never successfully started.
- Job - org.apache.flink.kubernetes.operator.utils.EventRecorder.Component
- JOB_NOT_FOUND_ERR - Static variable in class org.apache.flink.kubernetes.operator.observer.JobStatusObserver
- JOB_UPGRADE_IGNORE_PENDING_SAVEPOINT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- JOB_UPGRADE_INPLACE_SCALING_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- JOB_VERTEX_ID - Static variable in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- JobAutoScaler<KEY,Context extends JobAutoScalerContext<KEY>> - Interface in org.apache.flink.autoscaler
-
Flink Job AutoScaler.
- JobAutoScalerContext<KEY> - Class in org.apache.flink.autoscaler
-
The job autoscaler context, it includes all details related to the current job.
- JobAutoScalerContext() - Constructor for class org.apache.flink.autoscaler.JobAutoScalerContext
- JobAutoScalerImpl<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler
-
The default implementation of
JobAutoScaler
. - JobAutoScalerImpl(ScalingMetricCollector<KEY, Context>, ScalingMetricEvaluator, ScalingExecutor<KEY, Context>, AutoScalerEventHandler<KEY, Context>, ScalingRealizer<KEY, Context>, AutoScalerStateStore<KEY, Context>) - Constructor for class org.apache.flink.autoscaler.JobAutoScalerImpl
- JobDetailsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
The difference compared to 1.18 is that slot sharing group is optional here.
- JobDetailsInfo(JobID, String, boolean, JobStatus, long, long, long, long, long, Map<JobStatus, Long>, Collection<JobDetailsInfo.JobVertexDetailsInfo>, Map<ExecutionState, Integer>, JobPlanInfo.RawJson) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo
- JobDetailsInfo.JobVertexDetailsInfo - Class in org.apache.flink.runtime.rest.messages.job
-
Detailed information about a job vertex.
- JobKind - Enum in org.apache.flink.kubernetes.operator.api.spec
-
Describes the Kubernetes kind of job reference.
- JobListFetcher<KEY,Context extends JobAutoScalerContext<KEY>> - Interface in org.apache.flink.autoscaler.standalone
-
The JobListFetcher will fetch the jobContext of all jobs.
- JOBMANAGER_ENTRYPOINT_ARG - Static variable in class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneJobManagerDecorator
- JobManagerDeployment - org.apache.flink.kubernetes.operator.utils.EventRecorder.Component
- JobManagerDeploymentStatus - Enum in org.apache.flink.kubernetes.operator.api.status
-
Status of the Flink JobManager Kubernetes deployment.
- JobManagerSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
JobManager spec.
- JobManagerSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.JobManagerSpec
- JobReference - Class in org.apache.flink.kubernetes.operator.api.spec
-
Flink resource reference that can be a FlinkDeployment or FlinkSessionJob.
- JobReference() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.JobReference
- JobSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
Flink job spec.
- JobSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.JobSpec
- JobState - Enum in org.apache.flink.kubernetes.operator.api.spec
-
Enum describing the desired job state.
- JobStateView - Class in org.apache.flink.autoscaler.jdbc.state
-
The view of job state.
- JobStateView(JdbcStateInteractor, String) - Constructor for class org.apache.flink.autoscaler.jdbc.state.JobStateView
- JobStatus - Class in org.apache.flink.kubernetes.operator.api.status
-
Last observed status of the Flink job within an application deployment.
- JobStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.JobStatus
- JobStatusChanged - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- JobStatusObserver<R extends AbstractFlinkResource<?,?>> - Class in org.apache.flink.kubernetes.operator.observer
-
An observer to observe the job status.
- JobStatusObserver(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.JobStatusObserver
- JobStatusUtils - Class in org.apache.flink.autoscaler.utils
-
Job status related utilities.
- JobStatusUtils() - Constructor for class org.apache.flink.autoscaler.utils.JobStatusUtils
- jobsWithGcMetrics - Variable in class org.apache.flink.autoscaler.ScalingMetricCollector
- JobTopology - Class in org.apache.flink.autoscaler.topology
-
Structure representing information about the jobgraph that is relevant for scaling.
- JobTopology(Collection<VertexInfo>) - Constructor for class org.apache.flink.autoscaler.topology.JobTopology
- JobTopology(Set<VertexInfo>) - Constructor for class org.apache.flink.autoscaler.topology.JobTopology
- JobTopology(VertexInfo...) - Constructor for class org.apache.flink.autoscaler.topology.JobTopology
- JobUpgrade() - Constructor for class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler.JobUpgrade
- JobVertexDetailsInfo(JobVertexID, SlotSharingGroupId, String, int, int, ExecutionState, long, long, long, Map<ExecutionState, Integer>, IOMetricsInfo) - Constructor for class org.apache.flink.runtime.rest.messages.job.JobDetailsInfo.JobVertexDetailsInfo
- JobVertexScaler<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler
-
Component responsible for computing vertex parallelism based on the scaling metrics.
- JobVertexScaler(AutoScalerEventHandler<KEY, Context>) - Constructor for class org.apache.flink.autoscaler.JobVertexScaler
- JobVertexScaler.ParallelismChange - Class in org.apache.flink.autoscaler
-
The rescaling will be triggered if any vertex's ParallelismChange is required.
- JobVertexScaler.ParallelismChangeType - Enum in org.apache.flink.autoscaler
-
The parallelism change type of
JobVertexScaler.ParallelismChange
.
K
- K8S_OP_CONF_PREFIX - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- KIND_FLINK_DEPLOYMENT - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- KIND_FLINK_STATE_SNAPSHOT - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- KIND_SESSION_JOB - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- KUBE_CLIENT_GROUP - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- kubernetes(Instant) - Static method in class org.apache.flink.autoscaler.utils.DateTimeUtils
-
Convert an Instant to a format that is used in Kubernetes.
- KUBERNETES_TASKMANAGER_REPLICAS - Static variable in class org.apache.flink.kubernetes.operator.standalone.StandaloneKubernetesConfigOptionsInternal
- KubernetesAutoScalerEventHandler - Class in org.apache.flink.kubernetes.operator.autoscaler
-
An event handler which posts events to the Kubernetes events API.
- KubernetesAutoScalerEventHandler(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.autoscaler.KubernetesAutoScalerEventHandler
- KubernetesAutoScalerStateStore - Class in org.apache.flink.kubernetes.operator.autoscaler.state
-
An AutoscalerStateStore which persists its state in Kubernetes ConfigMaps.
- KubernetesAutoScalerStateStore(ConfigMapStore) - Constructor for class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- kubernetesClient - Variable in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- KubernetesClientMetrics - Class in org.apache.flink.kubernetes.operator.metrics
-
Kubernetes client metrics.
- KubernetesClientMetrics(MetricGroup, FlinkOperatorConfiguration) - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- KubernetesClientMetrics(MetricGroup, FlinkOperatorConfiguration, LongSupplier) - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- KubernetesClientUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Kubernetes client utils.
- KubernetesClientUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.KubernetesClientUtils
- KubernetesDeploymentMode - Enum in org.apache.flink.kubernetes.operator.api.spec
-
Enum to control Flink deployment mode on Kubernetes.
- KubernetesJobAutoScalerContext - Class in org.apache.flink.kubernetes.operator.autoscaler
-
An implementation of JobAutoscalerContext for Kubernetes.
- KubernetesJobAutoScalerContext(JobID, JobStatus, Configuration, MetricGroup, SupplierWithException<RestClusterClient<String>, Exception>, FlinkResourceContext<?>) - Constructor for class org.apache.flink.kubernetes.operator.autoscaler.KubernetesJobAutoScalerContext
- KubernetesNodeResourceInfo - Class in org.apache.flink.kubernetes.operator.resources
-
A single Kubernetes node and its resources (cpu / memory).
- KubernetesNodeResourceInfo() - Constructor for class org.apache.flink.kubernetes.operator.resources.KubernetesNodeResourceInfo
- KubernetesOperatorConfigOptions - Class in org.apache.flink.kubernetes.operator.config
-
This class holds configuration constants used by flink operator.
- KubernetesOperatorConfigOptions() - Constructor for class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- KubernetesOperatorMetricGroup - Class in org.apache.flink.kubernetes.operator.metrics
-
Base metric group for Flink Operator System metrics.
- KubernetesOperatorMetricOptions - Class in org.apache.flink.kubernetes.operator.metrics
-
Configuration options for metrics.
- KubernetesOperatorMetricOptions() - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- KubernetesOperatorScopeFormat - Class in org.apache.flink.kubernetes.operator.metrics
-
Format for metrics.
- KubernetesOperatorScopeFormat(String) - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorScopeFormat
- KubernetesResource - Class in org.apache.flink.kubernetes.operator.resources
-
A Kubernetes resource and its current allocation.
- KubernetesResource() - Constructor for class org.apache.flink.kubernetes.operator.resources.KubernetesResource
- KubernetesResourceMetricGroup - Class in org.apache.flink.kubernetes.operator.metrics
-
Base metric group for Flink Operator Resource level metrics.
- KubernetesResourceMetricGroup(MetricRegistry, KubernetesResourceNamespaceMetricGroup, String[], String) - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceMetricGroup
- KubernetesResourceNamespaceMetricGroup - Class in org.apache.flink.kubernetes.operator.metrics
-
Base metric group for Flink Operator Resource namespace level metrics.
- KubernetesResourceNamespaceMetricGroup(MetricRegistry, KubernetesOperatorMetricGroup, String[], String, String) - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceMetricGroup
- KubernetesResourceNamespaceScopeFormat - Class in org.apache.flink.kubernetes.operator.metrics
-
Format for metrics.
- KubernetesResourceNamespaceScopeFormat(String) - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceScopeFormat
- KubernetesResourceScopeFormat - Class in org.apache.flink.kubernetes.operator.metrics
-
Format for metrics.
- KubernetesResourceScopeFormat(String) - Constructor for class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceScopeFormat
- KubernetesScalingRealizer - Class in org.apache.flink.kubernetes.operator.autoscaler
-
The Kubernetes implementation for applying parallelism overrides.
- KubernetesScalingRealizer() - Constructor for class org.apache.flink.kubernetes.operator.autoscaler.KubernetesScalingRealizer
- KubernetesStandaloneClusterDescriptor - Class in org.apache.flink.kubernetes.operator.standalone
-
Standalone Kubernetes specific
ClusterDescriptor
implementation. - KubernetesStandaloneClusterDescriptor(Configuration, FlinkStandaloneKubeClient) - Constructor for class org.apache.flink.kubernetes.operator.standalone.KubernetesStandaloneClusterDescriptor
L
- LABEL_SNAPSHOT_JOB_REFERENCE_KIND - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- LABEL_SNAPSHOT_JOB_REFERENCE_NAME - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- LABEL_SNAPSHOT_STATE - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- LABEL_SNAPSHOT_TRIGGER_TYPE - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- LABEL_SNAPSHOT_TYPE - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- LABEL_TARGET_SESSION - Static variable in class org.apache.flink.kubernetes.operator.api.CrdConstants
- LABEL_TYPE_STANDALONE_TYPE - Static variable in class org.apache.flink.kubernetes.operator.utils.StandaloneKubernetesUtils
- LABELS - Static variable in class org.apache.flink.kubernetes.operator.utils.FlinkResourceExceptionUtils
- LAG - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Total number of pending records.
- LAST_STATE - org.apache.flink.kubernetes.operator.api.spec.UpgradeMode
-
Job is upgraded using any latest checkpoint or savepoint available.
- LAST_STATE - org.apache.flink.kubernetes.operator.service.SuspendMode
- LAST_STATE_DUMMY_SP_PATH - Static variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- lastSavepointKnown(CommonStatus<?>) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
-
Check if the last snapshot information is known.
- LifecycleMetrics<CR extends AbstractFlinkResource<?,?>> - Class in org.apache.flink.kubernetes.operator.metrics.lifecycle
-
Utility for tracking resource lifecycle metrics globally and per namespace.
- LifecycleMetrics(Configuration, KubernetesOperatorMetricGroup) - Constructor for class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics
- LifecycleMetrics.Transition - Class in org.apache.flink.kubernetes.operator.metrics.lifecycle
-
Pojo for encapsulating state transitions and whether we should measure time from the beginning of from or since the last update.
- ListenerUtils - Class in org.apache.flink.kubernetes.operator.listener
-
Flink resource listener utilities.
- ListenerUtils() - Constructor for class org.apache.flink.kubernetes.operator.listener.ListenerUtils
- LOAD - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Subtask load (busy time ratio 0 (idle) to 1 (fully utilized)).
- loadGlobalConfiguration(Optional<String>) - Static method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
- loadListenerConfigs(Configuration) - Static method in class org.apache.flink.kubernetes.operator.listener.ListenerUtils
- LoadSimulationPipeline - Class in autoscaling
-
Example pipeline which simulates fluctuating load from zero to a defined max, and vice-versa.
- LoadSimulationPipeline() - Constructor for class autoscaling.LoadSimulationPipeline
- LOG - Static variable in class org.apache.flink.kubernetes.operator.artifact.FileSystemBasedArtifactFetcher
- LOG - Static variable in class org.apache.flink.kubernetes.operator.artifact.HttpArtifactFetcher
- logContext(FlinkResourceListener.FlinkStateSnapshotEventContext) - Static method in class org.apache.flink.kubernetes.operator.listener.AuditUtils
- logContext(FlinkResourceListener.FlinkStateSnapshotStatusUpdateContext) - Static method in class org.apache.flink.kubernetes.operator.listener.AuditUtils
- logContext(FlinkResourceListener.ResourceEventContext<R>) - Static method in class org.apache.flink.kubernetes.operator.listener.AuditUtils
- logContext(FlinkResourceListener.StatusUpdateContext<R, S>) - Static method in class org.apache.flink.kubernetes.operator.listener.AuditUtils
- logEnvironmentInfo(Logger, String, String[]) - Static method in class org.apache.flink.kubernetes.operator.utils.EnvUtils
-
Logs information about the environment, like code revision, current user, Java version, and JVM parameters.
- logger - Variable in class org.apache.flink.kubernetes.operator.observer.AbstractFlinkResourceObserver
- logger - Variable in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- LOGGING - org.apache.flink.autoscaler.standalone.AutoscalerEventHandlerFactory.EventHandlerType
- LoggingEventHandler<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler.event
-
Autoscaler event handler which logs events.
- LoggingEventHandler() - Constructor for class org.apache.flink.autoscaler.event.LoggingEventHandler
M
- main(String[]) - Static method in class autoscaling.AutoscalingExample
- main(String[]) - Static method in class autoscaling.LoadSimulationPipeline
- main(String[]) - Static method in class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerEntrypoint
- main(String[]) - Static method in class org.apache.flink.kubernetes.operator.admission.FlinkOperatorWebhook
- main(String[]) - Static method in class org.apache.flink.kubernetes.operator.api.validation.CrdCompatibilityChecker
- main(String[]) - Static method in class org.apache.flink.kubernetes.operator.docs.configuration.ConfigOptionsDocGenerator
-
This method generates html tables from set of classes containing
ConfigOptions
. - main(String...) - Static method in class org.apache.flink.kubernetes.operator.FlinkOperator
- MALFORMED_MINOR_VERSION - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- MANAGED_MEMORY_USED - org.apache.flink.autoscaler.metrics.FlinkMetric
- MANAGED_MEMORY_USED - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Measured max managed memory size in bytes.
- MANUAL - org.apache.flink.kubernetes.operator.api.status.SnapshotTriggerType
-
Snapshot manually triggered by changing a triggerNonce.
- markEvent() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedMeterView
- markEvent(long) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedMeterView
- markReconciledSpecAsStable() - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- MAX - org.apache.flink.autoscaler.metrics.MetricAggregator
- MAX_CM_BYTES - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- MAX_PARALLELISM - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Job vertex max parallelism.
- MAX_SCALE_DOWN_FACTOR - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- MAX_SCALE_UP_FACTOR - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- measureFromLastUpdate - Variable in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics.Transition
- MEMORY - org.apache.flink.autoscaler.standalone.AutoscalerStateStoreFactory.StateStoreType
- MEMORY_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- MEMORY_QUOTA - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- MEMORY_SCALING_ENABLED - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- MEMORY_TUNING_ENABLED - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- MEMORY_TUNING_MAXIMIZE_MANAGED_MEMORY - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- MEMORY_TUNING_OVERHEAD - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- MemoryBudget - Class in org.apache.flink.autoscaler.tuning
-
Accounting for distributing memory over the available pools.
- MemoryBudget(long) - Constructor for class org.apache.flink.autoscaler.tuning.MemoryBudget
- MemoryPressure - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- MemoryScaling - Class in org.apache.flink.autoscaler.tuning
-
Memory scaling ensures that memory is scaled alongside with the number of available TaskManagers.
- MemoryScaling() - Constructor for class org.apache.flink.autoscaler.tuning.MemoryScaling
- MemoryTuning - Class in org.apache.flink.autoscaler.tuning
-
Tunes the TaskManager memory.
- MemoryTuning() - Constructor for class org.apache.flink.autoscaler.tuning.MemoryTuning
- mergePodTemplates(PodTemplateSpec, PodTemplateSpec, boolean) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- METASPACE_MEMORY_USED - org.apache.flink.autoscaler.metrics.FlinkMetric
- METASPACE_MEMORY_USED - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Measured max metaspace memory size in bytes.
- METER - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- MetricAggregator - Enum in org.apache.flink.autoscaler.metrics
-
Enum specifying which aggregator to use when getting a metric value.
- MetricManager<CR extends io.fabric8.kubernetes.client.CustomResource<?,?>> - Class in org.apache.flink.kubernetes.operator.metrics
-
Metric manager for Operator managed custom resources.
- MetricManager() - Constructor for class org.apache.flink.kubernetes.operator.metrics.MetricManager
- metricName - Variable in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics.Transition
- MetricNotFoundException - Exception in org.apache.flink.autoscaler.metrics
-
Exception for when an expected metric was not found.
- MetricNotFoundException(FlinkMetric, JobVertexID) - Constructor for exception org.apache.flink.autoscaler.metrics.MetricNotFoundException
- METRICS_WINDOW - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- MIN - org.apache.flink.autoscaler.metrics.MetricAggregator
- Missing - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- MISSING - org.apache.flink.kubernetes.operator.api.status.JobManagerDeploymentStatus
-
JobManager deployment not found, probably not started or killed by user.
- MissingJobManagerException - Exception in org.apache.flink.kubernetes.operator.exception
-
Exception to signal missing job manager.
- MissingJobManagerException(String) - Constructor for exception org.apache.flink.kubernetes.operator.exception.MissingJobManagerException
- MissingJobManagerException(String, Throwable) - Constructor for exception org.apache.flink.kubernetes.operator.exception.MissingJobManagerException
- MissingJobManagerException(Throwable) - Constructor for exception org.apache.flink.kubernetes.operator.exception.MissingJobManagerException
- mode() - Method in annotation type org.apache.flink.kubernetes.operator.api.diff.SpecDiff.Entry
- mode() - Method in annotation type org.apache.flink.kubernetes.operator.api.diff.SpecDiff
- Mode - Enum in org.apache.flink.kubernetes.operator.config
-
The mode of
FlinkDeployment
. - monitorSizeOf(T, String) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- MSG_ROLLBACK - Static variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- MSG_SPEC_CHANGED - Static variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- MSG_SUBMIT - Static variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- MSG_SUSPENDED - Static variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- mutate(HasMetadata, Operation) - Method in class org.apache.flink.kubernetes.operator.admission.mutator.FlinkMutator
- mutateDeployment(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.mutator.DefaultFlinkMutator
- mutateDeployment(FlinkDeployment) - Method in interface org.apache.flink.kubernetes.operator.mutator.FlinkResourceMutator
-
Mutate deployment and return the mutated Object.
- mutateSessionJob(FlinkSessionJob, Optional<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.mutator.DefaultFlinkMutator
- mutateSessionJob(FlinkSessionJob, Optional<FlinkDeployment>) - Method in interface org.apache.flink.kubernetes.operator.mutator.FlinkResourceMutator
-
Mutate session job and return the mutated Object.
- mutateStateSnapshot(FlinkStateSnapshot) - Method in class org.apache.flink.kubernetes.operator.mutator.DefaultFlinkMutator
- mutateStateSnapshot(FlinkStateSnapshot) - Method in interface org.apache.flink.kubernetes.operator.mutator.FlinkResourceMutator
-
Mutate snapshot and return the mutated Object.
- MUTATOR_REQUEST_PATH - Static variable in class org.apache.flink.kubernetes.operator.admission.AdmissionHandler
- MutatorUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Mutator utilities.
- MutatorUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.MutatorUtils
N
- name - Variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorScopeFormat
- namespace - Variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- NAMESPACE - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorScopeFormat
- NAMESPACE_CONF_PREFIX - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- NATIVE - org.apache.flink.kubernetes.operator.api.spec.KubernetesDeploymentMode
-
Deploys Flink using Flinks native Kubernetes support.
- NATIVE - org.apache.flink.kubernetes.operator.api.status.SavepointFormatType
-
A format specific for the chosen state backend.
- NativeFlinkService - Class in org.apache.flink.kubernetes.operator.service
-
Implementation of
FlinkService
submitting and interacting with Native Kubernetes Flink clusters and jobs. - NativeFlinkService(KubernetesClient, ArtifactManager, ExecutorService, FlinkOperatorConfiguration, EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- newConfigWithOverrides(Configuration) - Method in class org.apache.flink.autoscaler.tuning.ConfigChanges
- newEngine(ByteBufAllocator) - Method in class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- newEngine(ByteBufAllocator, String, int) - Method in class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- NO_CHANGE - org.apache.flink.autoscaler.JobVertexScaler.ParallelismChangeType
- noChange() - Static method in class org.apache.flink.autoscaler.JobVertexScaler.ParallelismChange
- NOOP - org.apache.flink.kubernetes.operator.service.SuspendMode
- NoopJobAutoscaler<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler
-
An autoscaler implementation which does nothing.
- NoopJobAutoscaler() - Constructor for class org.apache.flink.autoscaler.NoopJobAutoscaler
- NoopResourceCheck - Class in org.apache.flink.autoscaler.resources
-
Noop implementation for checking for available resources.
- NoopResourceCheck() - Constructor for class org.apache.flink.autoscaler.resources.NoopResourceCheck
- Normal - org.apache.flink.autoscaler.event.AutoScalerEventHandler.Type
- Normal - org.apache.flink.kubernetes.operator.utils.EventRecorder.Type
- notifyListeners(CR, STATUS) - Method in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
-
Notifies status update listeners of changes made to a resource.
- NotReadyException - Exception in org.apache.flink.autoscaler.exceptions
-
An exception to indicate the called code wasn't ready but will be at a later point in time.
- NotReadyException(Exception) - Constructor for exception org.apache.flink.autoscaler.exceptions.NotReadyException
- NUM_RECORDS_IN - org.apache.flink.autoscaler.metrics.ScalingMetric
- NUM_RECORDS_OUT - org.apache.flink.autoscaler.metrics.ScalingMetric
- NUM_SOURCE_PARTITIONS - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Source vertex partition count.
- NUM_TASK_SLOTS_AVAILABLE - org.apache.flink.autoscaler.metrics.FlinkMetric
- NUM_TASK_SLOTS_TOTAL - org.apache.flink.autoscaler.metrics.FlinkMetric
- NUM_TASK_SLOTS_USED - org.apache.flink.autoscaler.metrics.ScalingMetric
O
- objectMapper - Variable in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
- observe(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.observer.AbstractFlinkResourceObserver
- observe(FlinkResourceContext<CR>) - Method in interface org.apache.flink.kubernetes.operator.observer.Observer
-
Observe the flinkApp status, It will reflect the changed status on the flinkApp resource.
- observe(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.observer.ClusterHealthObserver
-
Observe the health of the flink cluster.
- observe(FlinkResourceContext<R>) - Method in class org.apache.flink.kubernetes.operator.observer.JobStatusObserver
-
Observe the status of the flink job.
- observe(FlinkStateSnapshotContext) - Method in class org.apache.flink.kubernetes.operator.observer.snapshot.StateSnapshotObserver
- OBSERVE_TRUE_PROCESSING_RATE_LAG_THRESHOLD - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- observeCheckpointStatus(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.observer.SnapshotObserver
- OBSERVED_TPR - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Observed true processing rate for sources.
- OBSERVED_TRUE_PROCESSING_RATE_MIN_OBSERVATIONS - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- OBSERVED_TRUE_PROCESSING_RATE_SWITCH_THRESHOLD - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- observeFlinkCluster(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
-
Observe the flinkApp status when the cluster is ready.
- observeFlinkCluster(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.ApplicationObserver
- observeFlinkCluster(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.SessionObserver
- observeInternal(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.observer.AbstractFlinkResourceObserver
-
Internal observer logic specific to each resource type.
- observeInternal(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- observeInternal(FlinkResourceContext<FlinkSessionJob>) - Method in class org.apache.flink.kubernetes.operator.observer.sessionjob.FlinkSessionJobObserver
- observeJmDeployment(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.observer.deployment.AbstractFlinkDeploymentObserver
- Observer<CR extends AbstractFlinkResource<?,?>> - Interface in org.apache.flink.kubernetes.operator.observer
-
The Observer of custom resource.
- observeSavepointStatus(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.observer.SnapshotObserver
- of(double) - Static method in class org.apache.flink.autoscaler.metrics.EvaluatedScalingMetric
- of(long, SnapshotTriggerType) - Static method in class org.apache.flink.kubernetes.operator.api.status.Checkpoint
- of(String) - Static method in enum org.apache.flink.autoscaler.topology.ShipStrategy
-
Generates a ShipStrategy from a string, or returns
ShipStrategy.UNKNOWN
if the value cannot match any ShipStrategy. - of(String, long, SnapshotTriggerType) - Static method in class org.apache.flink.kubernetes.operator.api.status.Savepoint
- of(String, SnapshotTriggerType) - Static method in class org.apache.flink.kubernetes.operator.api.status.Savepoint
- of(String, SnapshotTriggerType, SavepointFormatType) - Static method in class org.apache.flink.kubernetes.operator.api.status.Savepoint
- of(Configuration, KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.resources.ClusterResourceManager
- of(SnapshotTriggerType) - Static method in class org.apache.flink.kubernetes.operator.api.status.Checkpoint
- of(SnapshotTriggerType, CheckpointType) - Static method in class org.apache.flink.kubernetes.operator.api.status.Checkpoint
- OLD_K8S_OP_CONF_PREFIX - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- onDeploymentEvent(FlinkResourceListener.ResourceEventContext<FlinkDeployment>) - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener
- onDeploymentStatusUpdate(FlinkResourceListener.StatusUpdateContext<FlinkDeployment, FlinkDeploymentStatus>) - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener
- onFileOrDirectoryCreated(Path) - Method in class org.apache.flink.kubernetes.operator.fs.FileSystemWatchService
- onFileOrDirectoryDeleted(Path) - Method in class org.apache.flink.kubernetes.operator.fs.FileSystemWatchService
- onFileOrDirectoryModified(Path) - Method in class org.apache.flink.kubernetes.operator.fs.FileSystemWatchService
- onNullIgnore() - Method in annotation type org.apache.flink.kubernetes.operator.api.diff.SpecDiff
- onRemove(CR) - Method in interface org.apache.flink.kubernetes.operator.metrics.CustomResourceMetrics
- onRemove(CR) - Method in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics
- onRemove(CR) - Method in class org.apache.flink.kubernetes.operator.metrics.MetricManager
- onRemove(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- onRemove(FlinkSessionJob) - Method in class org.apache.flink.kubernetes.operator.metrics.FlinkSessionJobMetrics
- onRemove(FlinkStateSnapshot) - Method in class org.apache.flink.kubernetes.operator.metrics.FlinkStateSnapshotMetrics
- onSessionJobEvent(FlinkResourceListener.ResourceEventContext<FlinkSessionJob>) - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener
- onSessionJobStatusUpdate(FlinkResourceListener.StatusUpdateContext<FlinkSessionJob, FlinkSessionJobStatus>) - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener
- onStateSnapshotEvent(FlinkResourceListener.FlinkStateSnapshotEventContext) - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener
-
Called when a new FlinkStateSnapshot event is triggered.
- onStateSnapshotStatusUpdate(FlinkResourceListener.FlinkStateSnapshotStatusUpdateContext) - Method in interface org.apache.flink.kubernetes.operator.api.listener.FlinkResourceListener
-
Called when a FlinkStateSnapshot status gets updated.
- onTargetJobNotFound(FlinkResourceContext<R>) - Method in class org.apache.flink.kubernetes.operator.observer.JobStatusObserver
-
Callback when no matching target job was found on a cluster where jobs were found.
- onTimeout(FlinkResourceContext<R>) - Method in class org.apache.flink.kubernetes.operator.observer.JobStatusObserver
-
Callback when list jobs timeout.
- onUpdate(CR) - Method in interface org.apache.flink.kubernetes.operator.metrics.CustomResourceMetrics
- onUpdate(CR) - Method in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics
- onUpdate(CR) - Method in class org.apache.flink.kubernetes.operator.metrics.MetricManager
- onUpdate(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- onUpdate(FlinkSessionJob) - Method in class org.apache.flink.kubernetes.operator.metrics.FlinkSessionJobMetrics
- onUpdate(FlinkStateSnapshot) - Method in class org.apache.flink.kubernetes.operator.metrics.FlinkStateSnapshotMetrics
- onUpdate(ResourceLifecycleState, Instant) - Method in class org.apache.flink.kubernetes.operator.metrics.lifecycle.ResourceLifecycleMetricTracker
- onWatchStarted(Path) - Method in class org.apache.flink.kubernetes.operator.fs.FileSystemWatchService
- Operator - org.apache.flink.kubernetes.operator.utils.EventRecorder.Component
- OPERATOR_CHECKPOINT_TRIGGER_GRACE_PERIOD - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CHECKPOINT_TYPE - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CLUSTER_HEALTH_CHECK_CHECKPOINT_PROGRESS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CLUSTER_HEALTH_CHECK_CHECKPOINT_PROGRESS_WINDOW - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CLUSTER_HEALTH_CHECK_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CLUSTER_HEALTH_CHECK_RESTARTS_THRESHOLD - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CLUSTER_HEALTH_CHECK_RESTARTS_WINDOW - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CONFIG_CACHE_SIZE - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_CONFIG_CACHE_TIMEOUT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_DYNAMIC_CONFIG_CHECK_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_DYNAMIC_CONFIG_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_DYNAMIC_NAMESPACES_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_EXCEPTION_FIELD_MAX_LENGTH - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_EXCEPTION_LABEL_MAPPER - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_EXCEPTION_STACK_TRACE_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_EXCEPTION_STACK_TRACE_MAX_LENGTH - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_EXCEPTION_THROWABLE_LIST_MAX_COUNT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_FLINK_CLIENT_CANCEL_TIMEOUT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_FLINK_CLIENT_TIMEOUT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_HEALTH_PROBE_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_HEALTH_PROBE_PORT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JM_DEPLOYMENT_RECOVERY_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JM_SHUTDOWN_TTL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JM_STARTUP_PROBE_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JOB_RESTART_FAILED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JOB_SAVEPOINT_DISPOSE_ON_DELETE - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JOB_UPGRADE_LAST_STATE_CANCEL_JOB - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JOB_UPGRADE_LAST_STATE_CHECKPOINT_MAX_AGE - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JOB_UPGRADE_LAST_STATE_FALLBACK_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_JOSDK_METRICS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_JVM_METRICS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_KUBERNETES_CLIENT_METRICS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_KUBERNETES_CLIENT_METRICS_HTTP_RESPONSE_CODE_GROUPS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_LABEL_SELECTOR - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_LEADER_ELECTION_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_LEADER_ELECTION_LEASE_DURATION - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_LEADER_ELECTION_LEASE_NAME - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_LEADER_ELECTION_RENEW_DEADLINE - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_LEADER_ELECTION_RETRY_PERIOD - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_LIFECYCLE_METRICS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_LIFECYCLE_NAMESPACE_HISTOGRAMS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_METRICS_HISTOGRAM_SAMPLE_SIZE - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_OBSERVER_PROGRESS_CHECK_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_OBSERVER_REST_READY_DELAY - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RATE_LIMITER_LIMIT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RATE_LIMITER_PERIOD - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RECONCILE_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RECONCILE_PARALLELISM - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RESOURCE_CLEANUP_TIMEOUT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RESOURCE_METRICS_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- OPERATOR_RETRY_INITIAL_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RETRY_INTERVAL_MULTIPLIER - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RETRY_MAX_ATTEMPTS - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_RETRY_MAX_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_SAVEPOINT_CLEANUP_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_SAVEPOINT_FORMAT_TYPE - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_SAVEPOINT_HISTORY_MAX_AGE - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_SAVEPOINT_HISTORY_MAX_AGE_THRESHOLD - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_SAVEPOINT_HISTORY_MAX_COUNT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_SAVEPOINT_HISTORY_MAX_COUNT_THRESHOLD - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_SAVEPOINT_TRIGGER_GRACE_PERIOD - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_STOP_ON_INFORMER_ERROR - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_TERMINATION_TIMEOUT - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_USER_ARTIFACTS_BASE_DIR - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OPERATOR_WATCHED_NAMESPACES - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- operatorConfig - Variable in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- operatorConfig(String) - Static method in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- operatorConfigKey(String) - Static method in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- OperatorHealthHandler - Class in org.apache.flink.kubernetes.operator.health
-
Simple code which returns HTTP 200 messages if the service is live, and HTTP 500 messages if the service is down.
- OperatorHealthHandler() - Constructor for class org.apache.flink.kubernetes.operator.health.OperatorHealthHandler
- OperatorHealthService - Class in org.apache.flink.kubernetes.operator.health
-
Health probe service.
- OperatorHealthService(FlinkConfigManager) - Constructor for class org.apache.flink.kubernetes.operator.health.OperatorHealthService
- OperatorJosdkMetrics - Class in org.apache.flink.kubernetes.operator.metrics
-
Implementation of
Metrics
to monitor and forward JOSDK metrics toMetricRegistry
. - OperatorJosdkMetrics(KubernetesOperatorMetricGroup, FlinkConfigManager) - Constructor for class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- OperatorMetricUtils - Class in org.apache.flink.kubernetes.operator.metrics
-
Utility class for flink based operator metrics.
- OperatorMetricUtils() - Constructor for class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils
- OperatorMetricUtils.SynchronizedCounter - Class in org.apache.flink.kubernetes.operator.metrics
-
Thread safe
Counter
wrapper. - OperatorMetricUtils.SynchronizedHistogram - Class in org.apache.flink.kubernetes.operator.metrics
-
Thread safe
Histogram
wrapper. - OperatorMetricUtils.SynchronizedMeterView - Class in org.apache.flink.kubernetes.operator.metrics
-
Thread safe
MeterView
wrapper. - optional(int) - Static method in class org.apache.flink.autoscaler.JobVertexScaler.ParallelismChange
- OPTIONAL_CHANGE - org.apache.flink.autoscaler.JobVertexScaler.ParallelismChangeType
- org.apache.flink.autoscaler - package org.apache.flink.autoscaler
- org.apache.flink.autoscaler.config - package org.apache.flink.autoscaler.config
- org.apache.flink.autoscaler.event - package org.apache.flink.autoscaler.event
- org.apache.flink.autoscaler.exceptions - package org.apache.flink.autoscaler.exceptions
- org.apache.flink.autoscaler.jdbc.event - package org.apache.flink.autoscaler.jdbc.event
- org.apache.flink.autoscaler.jdbc.state - package org.apache.flink.autoscaler.jdbc.state
- org.apache.flink.autoscaler.metrics - package org.apache.flink.autoscaler.metrics
- org.apache.flink.autoscaler.realizer - package org.apache.flink.autoscaler.realizer
- org.apache.flink.autoscaler.resources - package org.apache.flink.autoscaler.resources
- org.apache.flink.autoscaler.standalone - package org.apache.flink.autoscaler.standalone
- org.apache.flink.autoscaler.standalone.config - package org.apache.flink.autoscaler.standalone.config
- org.apache.flink.autoscaler.standalone.flinkcluster - package org.apache.flink.autoscaler.standalone.flinkcluster
- org.apache.flink.autoscaler.standalone.realizer - package org.apache.flink.autoscaler.standalone.realizer
- org.apache.flink.autoscaler.standalone.utils - package org.apache.flink.autoscaler.standalone.utils
- org.apache.flink.autoscaler.state - package org.apache.flink.autoscaler.state
- org.apache.flink.autoscaler.topology - package org.apache.flink.autoscaler.topology
- org.apache.flink.autoscaler.tuning - package org.apache.flink.autoscaler.tuning
- org.apache.flink.autoscaler.utils - package org.apache.flink.autoscaler.utils
- org.apache.flink.kubernetes.operator - package org.apache.flink.kubernetes.operator
- org.apache.flink.kubernetes.operator.admission - package org.apache.flink.kubernetes.operator.admission
- org.apache.flink.kubernetes.operator.admission.informer - package org.apache.flink.kubernetes.operator.admission.informer
- org.apache.flink.kubernetes.operator.admission.mutator - package org.apache.flink.kubernetes.operator.admission.mutator
- org.apache.flink.kubernetes.operator.api - package org.apache.flink.kubernetes.operator.api
- org.apache.flink.kubernetes.operator.api.diff - package org.apache.flink.kubernetes.operator.api.diff
- org.apache.flink.kubernetes.operator.api.docs - package org.apache.flink.kubernetes.operator.api.docs
- org.apache.flink.kubernetes.operator.api.lifecycle - package org.apache.flink.kubernetes.operator.api.lifecycle
- org.apache.flink.kubernetes.operator.api.listener - package org.apache.flink.kubernetes.operator.api.listener
- org.apache.flink.kubernetes.operator.api.reconciler - package org.apache.flink.kubernetes.operator.api.reconciler
- org.apache.flink.kubernetes.operator.api.spec - package org.apache.flink.kubernetes.operator.api.spec
- org.apache.flink.kubernetes.operator.api.status - package org.apache.flink.kubernetes.operator.api.status
- org.apache.flink.kubernetes.operator.api.utils - package org.apache.flink.kubernetes.operator.api.utils
- org.apache.flink.kubernetes.operator.api.validation - package org.apache.flink.kubernetes.operator.api.validation
- org.apache.flink.kubernetes.operator.artifact - package org.apache.flink.kubernetes.operator.artifact
- org.apache.flink.kubernetes.operator.autoscaler - package org.apache.flink.kubernetes.operator.autoscaler
- org.apache.flink.kubernetes.operator.autoscaler.state - package org.apache.flink.kubernetes.operator.autoscaler.state
- org.apache.flink.kubernetes.operator.config - package org.apache.flink.kubernetes.operator.config
- org.apache.flink.kubernetes.operator.controller - package org.apache.flink.kubernetes.operator.controller
- org.apache.flink.kubernetes.operator.docs.configuration - package org.apache.flink.kubernetes.operator.docs.configuration
- org.apache.flink.kubernetes.operator.docs.util - package org.apache.flink.kubernetes.operator.docs.util
- org.apache.flink.kubernetes.operator.exception - package org.apache.flink.kubernetes.operator.exception
- org.apache.flink.kubernetes.operator.fs - package org.apache.flink.kubernetes.operator.fs
- org.apache.flink.kubernetes.operator.health - package org.apache.flink.kubernetes.operator.health
- org.apache.flink.kubernetes.operator.kubeclient - package org.apache.flink.kubernetes.operator.kubeclient
- org.apache.flink.kubernetes.operator.kubeclient.decorators - package org.apache.flink.kubernetes.operator.kubeclient.decorators
- org.apache.flink.kubernetes.operator.kubeclient.factory - package org.apache.flink.kubernetes.operator.kubeclient.factory
- org.apache.flink.kubernetes.operator.kubeclient.parameters - package org.apache.flink.kubernetes.operator.kubeclient.parameters
- org.apache.flink.kubernetes.operator.listener - package org.apache.flink.kubernetes.operator.listener
- org.apache.flink.kubernetes.operator.metrics - package org.apache.flink.kubernetes.operator.metrics
- org.apache.flink.kubernetes.operator.metrics.lifecycle - package org.apache.flink.kubernetes.operator.metrics.lifecycle
- org.apache.flink.kubernetes.operator.mutator - package org.apache.flink.kubernetes.operator.mutator
- org.apache.flink.kubernetes.operator.observer - package org.apache.flink.kubernetes.operator.observer
- org.apache.flink.kubernetes.operator.observer.deployment - package org.apache.flink.kubernetes.operator.observer.deployment
- org.apache.flink.kubernetes.operator.observer.sessionjob - package org.apache.flink.kubernetes.operator.observer.sessionjob
- org.apache.flink.kubernetes.operator.observer.snapshot - package org.apache.flink.kubernetes.operator.observer.snapshot
- org.apache.flink.kubernetes.operator.reconciler - package org.apache.flink.kubernetes.operator.reconciler
- org.apache.flink.kubernetes.operator.reconciler.deployment - package org.apache.flink.kubernetes.operator.reconciler.deployment
- org.apache.flink.kubernetes.operator.reconciler.diff - package org.apache.flink.kubernetes.operator.reconciler.diff
- org.apache.flink.kubernetes.operator.reconciler.sessionjob - package org.apache.flink.kubernetes.operator.reconciler.sessionjob
- org.apache.flink.kubernetes.operator.reconciler.snapshot - package org.apache.flink.kubernetes.operator.reconciler.snapshot
- org.apache.flink.kubernetes.operator.resources - package org.apache.flink.kubernetes.operator.resources
- org.apache.flink.kubernetes.operator.service - package org.apache.flink.kubernetes.operator.service
- org.apache.flink.kubernetes.operator.ssl - package org.apache.flink.kubernetes.operator.ssl
- org.apache.flink.kubernetes.operator.standalone - package org.apache.flink.kubernetes.operator.standalone
- org.apache.flink.kubernetes.operator.utils - package org.apache.flink.kubernetes.operator.utils
- org.apache.flink.kubernetes.operator.validation - package org.apache.flink.kubernetes.operator.validation
- org.apache.flink.runtime.rest.messages.job - package org.apache.flink.runtime.rest.messages.job
- org.apache.flink.runtime.rest.messages.job.metrics - package org.apache.flink.runtime.rest.messages.job.metrics
- org.apache.flink.runtime.rest.messages.json - package org.apache.flink.runtime.rest.messages.json
P
- PARALLELISM - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Job vertex parallelism.
- PARALLELISM_MAP_KEY - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesAutoScalerEventHandler
- PARALLELISM_OVERRIDES - org.apache.flink.autoscaler.jdbc.state.StateType
- PARALLELISM_OVERRIDES_KEY - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- parseKubernetes(String) - Static method in class org.apache.flink.autoscaler.utils.DateTimeUtils
-
Parses a Kubernetes-compatible datetime.
- parseResourceMemoryString(String) - Static method in class org.apache.flink.kubernetes.operator.config.FlinkConfigBuilder
- parseVertexScalingReports(String) - Static method in class org.apache.flink.autoscaler.event.AutoscalerEventUtils
-
Parse the scaling report from original scaling report event.
- patchAndCacheStatus(CR, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
-
Update the status of the provided kubernetes resource on the k8s cluster.
- pending() - Static method in class org.apache.flink.kubernetes.operator.observer.CheckpointFetchResult
- pending() - Static method in class org.apache.flink.kubernetes.operator.observer.CheckpointStatsResult
- pending() - Static method in class org.apache.flink.kubernetes.operator.observer.SavepointFetchResult
- pending() - Static method in class org.apache.flink.kubernetes.operator.service.FlinkService.CancelResult
- PENDING - org.apache.flink.kubernetes.operator.utils.SnapshotStatus
-
Snapshot is pending, could be in the retry phase in the case of manual snapshots.
- PENDING_RECORDS - org.apache.flink.autoscaler.metrics.FlinkMetric
- PendingCheckpointInfo() - Constructor for class org.apache.flink.kubernetes.operator.service.CheckpointHistoryWrapper.PendingCheckpointInfo
- PERIODIC - org.apache.flink.kubernetes.operator.api.status.SnapshotTriggerType
-
Snapshot periodically triggered by the operator.
- PERIODIC_CHECKPOINT_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- PERIODIC_SAVEPOINT_INTERVAL - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- PLUGINS_LISTENERS_CLASS - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- POD_IP_ARG - Static variable in class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneJobManagerDecorator
- POD_TEMPLATE_MERGE_BY_NAME - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- predicate - Variable in enum org.apache.flink.autoscaler.metrics.FlinkMetric
- PREFER_TRACKED_RESTART_TIME - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- prefix() - Method in annotation type org.apache.flink.kubernetes.operator.api.diff.SpecDiff.Entry
- prepareEventSources(EventSourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentController
- prepareEventSources(EventSourceContext<FlinkSessionJob>) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobController
- prepareEventSources(EventSourceContext<FlinkStateSnapshot>) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotController
- put(StateType, String) - Method in class org.apache.flink.autoscaler.jdbc.state.JobStateView
- putSerializedState(String, StateType, String) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateStore
- putSerializedState(KubernetesJobAutoScalerContext, String, String) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- putVariables(Map<String, String>) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceMetricGroup
- putVariables(Map<String, String>) - Method in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceMetricGroup
Q
- queryAggregatedMetricNames(RestClusterClient<?>, JobID, JobVertexID) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- queryAggregatedTmMetrics(RestClusterClient<?>, Map<String, FlinkMetric>) - Method in class org.apache.flink.autoscaler.RestApiMetricsCollector
- queryAggregatedVertexMetrics(Context, JobVertexID, Map<String, FlinkMetric>) - Method in class org.apache.flink.autoscaler.RestApiMetricsCollector
- queryAllAggregatedMetrics(Context, Map<JobVertexID, Map<String, FlinkMetric>>) - Method in class org.apache.flink.autoscaler.RestApiMetricsCollector
- queryAllAggregatedMetrics(Context, Map<JobVertexID, Map<String, FlinkMetric>>) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- queryData(String) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateInteractor
- queryEvents(String, String) - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcEventInteractor
- queryFilteredMetricNames(Context, JobTopology) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
-
Query the available metric names for each job vertex.
- queryJmMetrics(Context) - Method in class org.apache.flink.autoscaler.RestApiMetricsCollector
- queryJmMetrics(Context) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- queryJmMetrics(RestClusterClient<?>, Map<String, FlinkMetric>) - Method in class org.apache.flink.autoscaler.RestApiMetricsCollector
- queryLatestEvent(String, String, String) - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcEventInteractor
- queryTmMetrics(Context) - Method in class org.apache.flink.autoscaler.RestApiMetricsCollector
- queryTmMetrics(Context) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
R
- readable(Instant) - Static method in class org.apache.flink.autoscaler.utils.DateTimeUtils
-
Convert an Instant to a readable format for the system default zone.
- readable(Instant, ZoneId) - Static method in class org.apache.flink.autoscaler.utils.DateTimeUtils
-
Convert an Instant to a readable format for a given zone.
- READY - org.apache.flink.kubernetes.operator.api.status.JobManagerDeploymentStatus
-
JobManager is running and ready to receive REST API calls.
- readyToReconcile(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
-
Check whether the given Flink resource is ready to be reconciled or we are still waiting for any pending operation or condition first.
- readyToReconcile(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- readyToReconcile(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.SessionReconciler
- readyToReconcile(FlinkResourceContext<FlinkSessionJob>) - Method in class org.apache.flink.kubernetes.operator.reconciler.sessionjob.SessionJobReconciler
- realizeConfigOverrides(Context, ConfigChanges) - Method in interface org.apache.flink.autoscaler.realizer.ScalingRealizer
-
Updates the TaskManager memory configuration.
- realizeConfigOverrides(Context, ConfigChanges) - Method in class org.apache.flink.autoscaler.standalone.realizer.RescaleApiScalingRealizer
- realizeConfigOverrides(KubernetesJobAutoScalerContext, ConfigChanges) - Method in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesScalingRealizer
- realizeParallelismOverrides(Context, Map<String, String>) - Method in interface org.apache.flink.autoscaler.realizer.ScalingRealizer
-
Update job's parallelism to parallelismOverrides.
- realizeParallelismOverrides(Context, Map<String, String>) - Method in class org.apache.flink.autoscaler.standalone.realizer.RescaleApiScalingRealizer
- realizeParallelismOverrides(KubernetesJobAutoScalerContext, Map<String, String>) - Method in class org.apache.flink.kubernetes.operator.autoscaler.KubernetesScalingRealizer
- REASON_CRASH_LOOP_BACKOFF - Static variable in exception org.apache.flink.kubernetes.operator.exception.DeploymentFailedException
- REASON_ERR_IMAGE_PULL - Static variable in exception org.apache.flink.kubernetes.operator.exception.DeploymentFailedException
- REASON_IMAGE_PULL_BACKOFF - Static variable in exception org.apache.flink.kubernetes.operator.exception.DeploymentFailedException
- REBALANCE - org.apache.flink.autoscaler.topology.ShipStrategy
- receivedEvent(Event, Map<String, Object>) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- RECOMMENDED_PARALLELISM - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Recommended job vertex parallelism.
- reconcile(FlinkDeployment, Context) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentController
- reconcile(FlinkSessionJob, Context) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobController
- reconcile(FlinkStateSnapshot, Context<FlinkStateSnapshot>) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotController
- reconcile(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- reconcile(FlinkResourceContext<CR>) - Method in interface org.apache.flink.kubernetes.operator.reconciler.Reconciler
-
This is called when receiving the create or update event of the custom resource.
- reconcile(FlinkStateSnapshotContext) - Method in class org.apache.flink.kubernetes.operator.reconciler.snapshot.StateSnapshotReconciler
- reconcileCustomResource(ResourceID, RetryInfo, Map<String, Object>) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- reconcileOtherChanges(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
-
Reconcile any other changes required for this resource that are specific to the reconciler implementation.
- reconcileOtherChanges(FlinkResourceContext<CR>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
-
Triggers any pending manual or periodic snapshots and updates the status accordingly.
- reconcileOtherChanges(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.ApplicationReconciler
- reconcileOtherChanges(FlinkResourceContext<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.SessionReconciler
- Reconciler<CR extends AbstractFlinkResource<?,?>> - Interface in org.apache.flink.kubernetes.operator.reconciler
-
The interface of reconciler.
- ReconcilerFactory - Class in org.apache.flink.kubernetes.operator.reconciler.deployment
-
The factory to create reconciler based on app mode.
- ReconcilerFactory(EventRecorder, StatusRecorder<FlinkDeployment, FlinkDeploymentStatus>, JobAutoScaler<ResourceID, KubernetesJobAutoScalerContext>) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.deployment.ReconcilerFactory
- reconcileSpecChange(DiffType, FlinkResourceContext<CR>, Configuration, SPEC) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
-
Reconcile spec upgrade on the currently deployed/suspended Flink resource and update the status accordingly.
- reconcileSpecChange(DiffType, FlinkResourceContext<CR>, Configuration, SPEC) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- reconcileSpecChange(DiffType, FlinkResourceContext<FlinkDeployment>, Configuration, FlinkDeploymentSpec) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.SessionReconciler
- ReconciliationException - Exception in org.apache.flink.kubernetes.operator.exception
-
Exception for wrapping reconciliation errors.
- ReconciliationException(String) - Constructor for exception org.apache.flink.kubernetes.operator.exception.ReconciliationException
- ReconciliationException(String, Throwable) - Constructor for exception org.apache.flink.kubernetes.operator.exception.ReconciliationException
- ReconciliationException(Throwable) - Constructor for exception org.apache.flink.kubernetes.operator.exception.ReconciliationException
- ReconciliationMetadata - Class in org.apache.flink.kubernetes.operator.api.reconciler
-
Extra metadata to be attached to the reconciled spec.
- ReconciliationMetadata() - Constructor for class org.apache.flink.kubernetes.operator.api.reconciler.ReconciliationMetadata
- ReconciliationState - Enum in org.apache.flink.kubernetes.operator.api.status
-
Current state of the reconciliation.
- ReconciliationStatus<SPEC extends AbstractFlinkSpec> - Class in org.apache.flink.kubernetes.operator.api.status
-
Status of the last reconcile step for the FlinkDeployment/FlinkSessionJob.
- ReconciliationStatus() - Constructor for class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- ReconciliationUtils - Class in org.apache.flink.kubernetes.operator.reconciler
-
Reconciliation utilities.
- ReconciliationUtils() - Constructor for class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- recordRestartDurationIfTrackedAndParallelismMatches(Instant, JobTopology, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Method in class org.apache.flink.autoscaler.ScalingTracking
-
Sets restart duration for the latest scaling record if its parallelism matches the current job parallelism.
- RecoverDeployment - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- ReflectiveDiffBuilder<T> - Class in org.apache.flink.kubernetes.operator.reconciler.diff
-
Assists in comparing
Diffable
objects with reflection. - ReflectiveDiffBuilder(KubernetesDeploymentMode, T, T) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.diff.ReflectiveDiffBuilder
- REFRESH_CLUSTER_RESOURCE_VIEW - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- register(CustomResourceMetrics<CR>) - Method in class org.apache.flink.kubernetes.operator.metrics.MetricManager
- registerCanaryResourceManager(CanaryResourceManager<?>) - Method in enum org.apache.flink.kubernetes.operator.health.HealthProbe
- registerScalingMetrics(List<JobVertexID>, Supplier<EvaluatedMetrics>) - Method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- release(double) - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesResource
- release(double, MemorySize) - Method in class org.apache.flink.kubernetes.operator.resources.ClusterResourceView
- reload() - Method in class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- ReloadableSslContext - Class in org.apache.flink.kubernetes.operator.ssl
-
SSL context which is able to reload keystore.
- ReloadableSslContext(String, String, String) - Constructor for class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- remove(StateType) - Method in class org.apache.flink.autoscaler.jdbc.state.JobStateView
- removeCachedStatus(CR) - Method in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
-
Remove cached status for Flink resource.
- removeCollectedMetrics(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- removeCollectedMetrics(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- removeCollectedMetrics(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- removeCollectedMetrics(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- removeConfigChanges(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- removeConfigChanges(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- removeConfigChanges(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- removeConfigChanges(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- removeInfoFromCache(ResourceID) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- removeInfoFromCache(ResourceID) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- removeInfoFromCache(String) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateStore
- removeInfoFromCache(KEY) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- removeInfoFromCache(KEY) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
-
Clean up all information related to the current job.
- removeInfoFromCache(KEY) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- removeLastValidClusterHealthInfo(Map<String, String>) - Static method in class org.apache.flink.kubernetes.operator.observer.ClusterHealthEvaluator
- removeOldRecords(Instant, Duration, int) - Method in class org.apache.flink.autoscaler.ScalingTracking
-
Removes all but one records from the internal map that are older than the specified time span and trims the number of records to the specified maximum count.
- removeOperatorConfigs(Configuration) - Static method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- removeParallelismOverrides(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- removeParallelismOverrides(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- removeParallelismOverrides(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- removeParallelismOverrides(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- removeScalingHistory(Context) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- removeScalingHistory(Context) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- removeScalingHistory(Context) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- removeScalingHistory(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- removeSerializedState(String, StateType) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateStore
- removeSerializedState(KubernetesJobAutoScalerContext, String) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.ConfigMapStore
- REPORTED_VERTEX_METRICS - Static variable in enum org.apache.flink.autoscaler.metrics.ScalingMetric
-
List of
ScalingMetric
s to be reported as per vertex Flink metrics. - REQUEST_START_TIME_HEADER - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesClientMetrics
- requestJobResult(Configuration, JobID) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- requestJobResult(Configuration, JobID) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- required(int) - Static method in class org.apache.flink.autoscaler.JobVertexScaler.ParallelismChange
- REQUIRED_CHANGE - org.apache.flink.autoscaler.JobVertexScaler.ParallelismChangeType
- RESCALE - org.apache.flink.autoscaler.topology.ShipStrategy
- RescaleApiScalingRealizer<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler.standalone.realizer
-
A ScalingRealizer which uses the Rescale API to apply parallelism changes.
- RescaleApiScalingRealizer(AutoScalerEventHandler<KEY, Context>) - Constructor for class org.apache.flink.autoscaler.standalone.realizer.RescaleApiScalingRealizer
- rescheduleAfter(JobManagerDeploymentStatus, FlinkDeployment, FlinkOperatorConfiguration) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- resetPending() - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesNodeResourceInfo
- resetRecommendedParallelism(Map<JobVertexID, Map<ScalingMetric, EvaluatedScalingMetric>>) - Static method in class org.apache.flink.autoscaler.metrics.AutoscalerFlinkMetrics
- resetSnapshotTriggers(AbstractFlinkResource<?, ?>, EventRecorder, KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
- resetTrigger() - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- resetTrigger() - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- resetTrigger() - Method in interface org.apache.flink.kubernetes.operator.api.status.SnapshotInfo
-
Deprecated.
- Resource - Class in org.apache.flink.kubernetes.operator.api.spec
-
Resource spec.
- Resource() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.Resource
- RESOURCE - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceScopeFormat
- RESOURCE_DELETION_PROPAGATION - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- RESOURCE_NS - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceScopeFormat
- RESOURCE_QUOTA_REACHED_MESSAGE - Static variable in class org.apache.flink.autoscaler.ScalingExecutor
- RESOURCE_TYPE - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesResourceNamespaceScopeFormat
- RESOURCE_USAGE_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- ResourceCheck - Interface in org.apache.flink.autoscaler.resources
-
An interface for checking the available capacity of the underlying resources.
- ResourceCheckUtils - Class in org.apache.flink.autoscaler.utils
-
Utils methods for resource checks.
- ResourceCheckUtils() - Constructor for class org.apache.flink.autoscaler.utils.ResourceCheckUtils
- ResourceLifecycleMetricTracker - Class in org.apache.flink.kubernetes.operator.metrics.lifecycle
-
Lifecycle state transition tracker for a single resource.
- ResourceLifecycleMetricTracker(ResourceLifecycleState, Instant, Map<String, List<Histogram>>, Map<ResourceLifecycleState, List<Histogram>>) - Constructor for class org.apache.flink.kubernetes.operator.metrics.lifecycle.ResourceLifecycleMetricTracker
- ResourceLifecycleState - Enum in org.apache.flink.kubernetes.operator.api.lifecycle
-
Enum encapsulating the lifecycle state of a Flink resource.
- resourceMetricGroups - Variable in class org.apache.flink.kubernetes.operator.service.FlinkResourceContextFactory
- ResourceQuotaReached - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- RestApiMetricsCollector<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler
-
Metric collector using flink rest api.
- RestApiMetricsCollector() - Constructor for class org.apache.flink.autoscaler.RestApiMetricsCollector
- RESTART_TIME - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- RestartUnhealthyJob - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- restoreJob(FlinkResourceContext<CR>, SPEC, Configuration, boolean) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- resubmitJob(FlinkResourceContext<CR>, boolean) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
- Rollback - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- ROLLED_BACK - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- ROLLED_BACK - org.apache.flink.kubernetes.operator.api.status.ReconciliationState
-
Rolled back to the lastStableSpec.
- ROLLING_BACK - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- ROLLING_BACK - org.apache.flink.kubernetes.operator.api.status.ReconciliationState
-
In the process of rolling back to the lastStableSpec.
- roundMetric(double) - Static method in class org.apache.flink.autoscaler.metrics.ScalingMetrics
- run() - Method in class org.apache.flink.kubernetes.operator.FlinkOperator
- run() - Method in class org.apache.flink.kubernetes.operator.fs.FileSystemWatchService
- run(DocletEnvironment) - Method in class org.apache.flink.kubernetes.operator.api.docs.CrdReferenceDoclet
- runJar(JobSpec, JobID, JarUploadResponseBody, Configuration, String) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- RUNNING - org.apache.flink.kubernetes.operator.api.spec.JobState
-
Job is expected to be processing data.
S
- Savepoint - Class in org.apache.flink.kubernetes.operator.api.status
-
Represents information about a finished savepoint.
- Savepoint(long, String, SnapshotTriggerType, SavepointFormatType, Long) - Constructor for class org.apache.flink.kubernetes.operator.api.status.Savepoint
- SAVEPOINT - org.apache.flink.kubernetes.operator.api.spec.UpgradeMode
-
Job is upgraded by first taking a savepoint of the running job, shutting it down and restoring from the savepoint.
- SAVEPOINT - org.apache.flink.kubernetes.operator.reconciler.SnapshotType
- SAVEPOINT - org.apache.flink.kubernetes.operator.service.SuspendMode
- SAVEPOINT_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkStateSnapshotMetrics
- SAVEPOINT_ON_DELETION - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- SAVEPOINT_REDEPLOY - org.apache.flink.kubernetes.operator.api.diff.DiffType
-
Full redeploy from new state.
- SavepointError - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- SavepointFetchResult - Class in org.apache.flink.kubernetes.operator.observer
-
Result of a fetch savepoint operation.
- SavepointFetchResult() - Constructor for class org.apache.flink.kubernetes.operator.observer.SavepointFetchResult
- SavepointFormatType - Enum in org.apache.flink.kubernetes.operator.api.status
-
Savepoint format type.
- SavepointInfo - Class in org.apache.flink.kubernetes.operator.api.status
-
Deprecated.
- SavepointInfo() - Constructor for class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- savepointInProgress(JobStatus) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
- savepointJobOrError(RestClusterClient<String>, CommonStatus<?>, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- SavepointSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
Spec for savepoint state snapshots.
- SavepointSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.SavepointSpec
- scale(Context) - Method in interface org.apache.flink.autoscaler.JobAutoScaler
-
Compute and apply new parallelism overrides for the provided job context.
- scale(Context) - Method in class org.apache.flink.autoscaler.JobAutoScalerImpl
- scale(Context) - Method in class org.apache.flink.autoscaler.NoopJobAutoscaler
- scale(FlinkResourceContext<?>, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- scale(FlinkResourceContext<?>, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- scale(FlinkResourceContext<?>, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- scale(JobVertexID, int, Collection<ShipStrategy>, int, int, double, int, int, AutoScalerEventHandler<KEY, Context>, Context) - Static method in class org.apache.flink.autoscaler.JobVertexScaler
-
Computing the newParallelism.
- SCALE - org.apache.flink.kubernetes.operator.api.diff.DiffType
-
Scalable spec change.
- SCALE_DOWN_INTERVAL - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- SCALE_DOWN_RATE_THRESHOLD - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Lower boundary of the target data rate range.
- SCALE_LIMITED_MESSAGE_FORMAT - Static variable in class org.apache.flink.autoscaler.JobVertexScaler
- SCALE_UP_RATE_THRESHOLD - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Upper boundary of the target data rate range.
- scaleResource(Context, EvaluatedMetrics, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>, ScalingTracking, Instant, JobTopology, DelayedScaleDown) - Method in class org.apache.flink.autoscaler.ScalingExecutor
- scaling() - Method in class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerExecutor
- Scaling - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- SCALING_EFFECTIVENESS_DETECTION_ENABLED - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- SCALING_EFFECTIVENESS_THRESHOLD - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- SCALING_ENABLED - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- SCALING_EVENT_INTERVAL - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- SCALING_EXECUTION_DISABLED_REASON - Static variable in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- SCALING_HISTORY - org.apache.flink.autoscaler.jdbc.state.StateType
- SCALING_HISTORY_KEY - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- SCALING_LIMITED - Static variable in class org.apache.flink.autoscaler.JobVertexScaler
- SCALING_REPORT_KEY - Static variable in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- SCALING_REPORT_REASON - Static variable in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- SCALING_SUMMARY_ENTRY - Static variable in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- SCALING_SUMMARY_HEADER_SCALING_EXECUTION_DISABLED - Static variable in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- SCALING_SUMMARY_HEADER_SCALING_EXECUTION_ENABLED - Static variable in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- SCALING_TRACKING - org.apache.flink.autoscaler.jdbc.state.StateType
- SCALING_TRACKING_KEY - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- ScalingExecutor<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler
-
Class responsible for executing scaling decisions.
- ScalingExecutor(AutoScalerEventHandler<KEY, Context>, AutoScalerStateStore<KEY, Context>) - Constructor for class org.apache.flink.autoscaler.ScalingExecutor
- ScalingExecutor(AutoScalerEventHandler<KEY, Context>, AutoScalerStateStore<KEY, Context>, ResourceCheck) - Constructor for class org.apache.flink.autoscaler.ScalingExecutor
- ScalingHistoryUtils - Class in org.apache.flink.autoscaler.metrics
-
The utils for scaling history.
- ScalingHistoryUtils() - Constructor for class org.apache.flink.autoscaler.metrics.ScalingHistoryUtils
- ScalingMetric - Enum in org.apache.flink.autoscaler.metrics
-
Supported scaling metrics.
- ScalingMetricCollector<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler
-
Metric collector using flink rest api.
- ScalingMetricCollector() - Constructor for class org.apache.flink.autoscaler.ScalingMetricCollector
- ScalingMetricEvaluator - Class in org.apache.flink.autoscaler
-
Job scaling evaluator for autoscaler.
- ScalingMetricEvaluator() - Constructor for class org.apache.flink.autoscaler.ScalingMetricEvaluator
- ScalingMetrics - Class in org.apache.flink.autoscaler.metrics
-
Utilities for computing scaling metrics based on Flink metrics.
- ScalingMetrics() - Constructor for class org.apache.flink.autoscaler.metrics.ScalingMetrics
- ScalingRealizer<KEY,Context extends JobAutoScalerContext<KEY>> - Interface in org.apache.flink.autoscaler.realizer
-
The Scaling Realizer is responsible for applying scaling actions, i.e.
- ScalingRecord - Class in org.apache.flink.autoscaler
-
Class for tracking scaling details, including time it took for the job to transition to the target parallelism.
- ScalingRecord() - Constructor for class org.apache.flink.autoscaler.ScalingRecord
- scalingReport(Map<JobVertexID, ScalingSummary>, String) - Static method in interface org.apache.flink.autoscaler.event.AutoScalerEventHandler
- ScalingReport - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- scalingSingleJob(Context) - Method in class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerExecutor
- ScalingSummary - Class in org.apache.flink.autoscaler
-
Scaling summary returned by the
ScalingMetricEvaluator
. - ScalingSummary(int, int, Map<ScalingMetric, EvaluatedScalingMetric>) - Constructor for class org.apache.flink.autoscaler.ScalingSummary
- ScalingTracking - Class in org.apache.flink.autoscaler
-
Stores rescaling related information for the job.
- ScalingTracking() - Constructor for class org.apache.flink.autoscaler.ScalingTracking
- scalingWouldExceedMaxResources(Configuration, JobTopology, EvaluatedMetrics, Map<JobVertexID, ScalingSummary>, Context) - Method in class org.apache.flink.autoscaler.ScalingExecutor
- scalingWouldExceedResourceQuota(Configuration, JobTopology, Map<JobVertexID, ScalingSummary>, JobAutoScalerContext<?>) - Static method in class org.apache.flink.autoscaler.ScalingExecutor
- SCOPE_NAMING_KUBERNETES_OPERATOR - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- SCOPE_NAMING_KUBERNETES_OPERATOR_RESOURCE - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- SCOPE_NAMING_KUBERNETES_OPERATOR_RESOURCENS - Static variable in class org.apache.flink.kubernetes.operator.metrics.KubernetesOperatorMetricOptions
- SECTION_ADVANCED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- SECTION_DYNAMIC - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- SECTION_SYSTEM - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- sendResponse(ChannelHandlerContext, String) - Static method in class org.apache.flink.kubernetes.operator.admission.AdmissionHandler
- serialize(ClusterHealthInfo) - Static method in class org.apache.flink.kubernetes.operator.health.ClusterHealthInfo
- serialize(SlotSharingGroupId, JsonGenerator, SerializerProvider) - Method in class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDSerializer
- serializeAndSetLastReconciledSpec(SPEC, AbstractFlinkResource<SPEC, ?>) - Method in class org.apache.flink.kubernetes.operator.api.status.ReconciliationStatus
- serializeEvaluatedMetrics(SortedMap<Instant, CollectedMetrics>) - Static method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- serializeEvaluatedMetrics(SortedMap<Instant, CollectedMetrics>) - Static method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- serializeScalingHistory(Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Static method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- serializeScalingHistory(Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Static method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- serializeScalingTracking(ScalingTracking) - Static method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- serializeScalingTracking(ScalingTracking) - Static method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- SESSION - org.apache.flink.kubernetes.operator.config.Mode
- SESSION - org.apache.flink.kubernetes.operator.standalone.StandaloneKubernetesConfigOptionsInternal.ClusterMode
- sessionClusterReady(Optional<FlinkDeployment>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.sessionjob.SessionJobReconciler
- sessionContext() - Method in class org.apache.flink.kubernetes.operator.ssl.ReloadableSslContext
- SessionJobReconciler - Class in org.apache.flink.kubernetes.operator.reconciler.sessionjob
-
The reconciler for the
FlinkSessionJob
. - SessionJobReconciler(EventRecorder, StatusRecorder<FlinkSessionJob, FlinkSessionJobStatus>, JobAutoScaler<ResourceID, KubernetesJobAutoScalerContext>) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.sessionjob.SessionJobReconciler
- SessionObserver - Class in org.apache.flink.kubernetes.operator.observer.deployment
-
The observer of the
Mode.SESSION
cluster. - SessionObserver(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.deployment.SessionObserver
- SessionReconciler - Class in org.apache.flink.kubernetes.operator.reconciler.deployment
-
Reconciler responsible for handling the session cluster lifecycle according to the desired and current states.
- SessionReconciler(EventRecorder, StatusRecorder<FlinkDeployment, FlinkDeploymentStatus>) - Constructor for class org.apache.flink.kubernetes.operator.reconciler.deployment.SessionReconciler
- setClock(Clock) - Method in class org.apache.flink.autoscaler.JobVertexScaler
- setClock(Clock) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- setClock(Clock) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- setGenerationAnnotation(Configuration, Long) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkUtils
- setLastValidClusterHealthInfo(Map<String, String>, ClusterHealthInfo) - Static method in class org.apache.flink.kubernetes.operator.observer.ClusterHealthEvaluator
- setNamespaces(Set<String>) - Method in class org.apache.flink.kubernetes.operator.admission.informer.InformerManager
- setOwnerReference(CR, Configuration) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- setRuntimeInfo(RuntimeInfo) - Method in enum org.apache.flink.kubernetes.operator.health.HealthProbe
- setTrigger(String, SnapshotTriggerType, CheckpointType) - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.
- setTrigger(String, SnapshotTriggerType, SavepointFormatType) - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.
- setUpgradeSavepointPath(FlinkResourceContext<?>, String) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractJobReconciler
-
Updates the upgrade savepoint field in the JobSpec of the current Flink resource and if snapshot resources are enabled, a new FlinkStateSnapshot will be created.
- ShipStrategy - Enum in org.apache.flink.autoscaler.topology
-
The ship strategy between 2 JobVertices.
- shouldRecoverDeployment(Configuration, FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
-
Checks whether the JobManager Kubernetes Deployment recovery logic should be initiated.
- shouldTriggerSnapshot(AbstractFlinkResource<?, ?>, Configuration, SnapshotType, Instant) - Static method in class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
-
Checks whether a snapshot should be triggered based on the current status and spec, and if yes, returns the correct
SnapshotTriggerType
. - SHUFFLE - org.apache.flink.autoscaler.topology.ShipStrategy
- SlotSharingGroupIdConverter - Class in org.apache.flink.runtime.rest.messages.json
-
Copied from Flink.
- SlotSharingGroupIdConverter() - Constructor for class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIdConverter
- SlotSharingGroupIDDeserializer - Class in org.apache.flink.runtime.rest.messages.json
-
Copied from Flink.
- SlotSharingGroupIDDeserializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDDeserializer
- SlotSharingGroupIDSerializer - Class in org.apache.flink.runtime.rest.messages.json
-
Copied from Flink.
- SlotSharingGroupIDSerializer() - Constructor for class org.apache.flink.runtime.rest.messages.json.SlotSharingGroupIDSerializer
- Snapshot - org.apache.flink.kubernetes.operator.utils.EventRecorder.Component
- Snapshot - Interface in org.apache.flink.kubernetes.operator.api.status
-
A common interface for
Checkpoint
andSavepoint
. - SNAPSHOT_RESOURCE_ENABLED - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- SnapshotAbandoned - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- SnapshotError - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- SnapshotInfo - Interface in org.apache.flink.kubernetes.operator.api.status
-
Deprecated.
- snapshotInProgress(FlinkStateSnapshot, String) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Sets a snapshot's state to
FlinkStateSnapshotStatus.State.IN_PROGRESS
. - SnapshotObserver<CR extends AbstractFlinkResource<?,STATUS>,STATUS extends CommonStatus<?>> - Class in org.apache.flink.kubernetes.operator.observer
-
An observer of savepoint progress.
- SnapshotObserver(EventRecorder) - Constructor for class org.apache.flink.kubernetes.operator.observer.SnapshotObserver
- SnapshotStatus - Enum in org.apache.flink.kubernetes.operator.utils
-
Enum encapsulating the lifecycle state of a Flink snapshot.
- snapshotSuccessful(FlinkStateSnapshot, String, boolean) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Sets a snapshot's state to
FlinkStateSnapshotStatus.State.COMPLETED
. - snapshotTriggerPending(FlinkStateSnapshot) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkStateSnapshotUtils
-
Sets a snapshot's state to
FlinkStateSnapshotStatus.State.TRIGGER_PENDING
. - SnapshotTriggerTimestampStore - Class in org.apache.flink.kubernetes.operator.reconciler
-
Class used to store latest timestamps of periodic checkpoint/savepoint.
- SnapshotTriggerTimestampStore() - Constructor for class org.apache.flink.kubernetes.operator.reconciler.SnapshotTriggerTimestampStore
- SnapshotTriggerType - Enum in org.apache.flink.kubernetes.operator.api.status
-
Snapshot trigger mechanism.
- SnapshotType - Enum in org.apache.flink.kubernetes.operator.reconciler
-
This enumeration represents the types of state snapshots that can be taken in Flink.
- SnapshotUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Savepoint utilities.
- SnapshotUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.SnapshotUtils
- SOURCE_TASK_NUM_RECORDS_IN - org.apache.flink.autoscaler.metrics.FlinkMetric
- SOURCE_TASK_NUM_RECORDS_IN_PER_SEC - org.apache.flink.autoscaler.metrics.FlinkMetric
- SOURCE_TASK_NUM_RECORDS_OUT - org.apache.flink.autoscaler.metrics.FlinkMetric
- SOURCE_TASK_NUM_RECORDS_OUT_PER_SEC - org.apache.flink.autoscaler.metrics.FlinkMetric
- SpecChanged - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- SpecDiff - Annotation Type in org.apache.flink.kubernetes.operator.api.diff
-
Spec diff annotation.
- SpecDiff.Config - Annotation Type in org.apache.flink.kubernetes.operator.api.diff
-
Spec diff config annotation.
- SpecDiff.Entry - Annotation Type in org.apache.flink.kubernetes.operator.api.diff
-
Spec diff config annotation entry.
- SpecUtils - Class in org.apache.flink.kubernetes.operator.api.utils
-
Spec utilities.
- SpecUtils() - Constructor for class org.apache.flink.kubernetes.operator.api.utils.SpecUtils
- SpecWithMeta<T extends AbstractFlinkSpec> - Class in org.apache.flink.kubernetes.operator.api.utils
-
Utility class for encapsulating Kubernetes resource spec and meta fields during serialization.
- SpecWithMeta() - Constructor for class org.apache.flink.kubernetes.operator.api.utils.SpecWithMeta
- STABILIZATION_INTERVAL - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- STABLE - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- STANDALONE - org.apache.flink.kubernetes.operator.api.spec.KubernetesDeploymentMode
-
Deploys Flink on-top of kubernetes in standalone mode.
- StandaloneAutoscalerEntrypoint - Class in org.apache.flink.autoscaler.standalone
-
The entrypoint of the standalone autoscaler.
- StandaloneAutoscalerEntrypoint() - Constructor for class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerEntrypoint
- StandaloneAutoscalerExecutor<KEY,Context extends JobAutoScalerContext<KEY>> - Class in org.apache.flink.autoscaler.standalone
-
The executor of the standalone autoscaler.
- StandaloneAutoscalerExecutor(Configuration, JobListFetcher<KEY, Context>, AutoScalerEventHandler<KEY, Context>, JobAutoScaler<KEY, Context>) - Constructor for class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerExecutor
- StandaloneFlinkService - Class in org.apache.flink.kubernetes.operator.service
-
Implementation of
FlinkService
submitting and interacting with Standalone Kubernetes Flink clusters and jobs. - StandaloneFlinkService(KubernetesClient, ArtifactManager, ExecutorService, FlinkOperatorConfiguration) - Constructor for class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- StandaloneKubernetesConfigOptionsInternal - Class in org.apache.flink.kubernetes.operator.standalone
-
This class holds internal configuration constants used by flink operator when deploying flink clusters in standalone mode.
- StandaloneKubernetesConfigOptionsInternal() - Constructor for class org.apache.flink.kubernetes.operator.standalone.StandaloneKubernetesConfigOptionsInternal
- StandaloneKubernetesConfigOptionsInternal.ClusterMode - Enum in org.apache.flink.kubernetes.operator.standalone
-
The different modes that a Flink cluster can be deployed in.
- StandaloneKubernetesJobManagerFactory - Class in org.apache.flink.kubernetes.operator.kubeclient.factory
-
Utility class for constructing all the Kubernetes for the JobManager deploying in standalone mode.
- StandaloneKubernetesJobManagerFactory() - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.factory.StandaloneKubernetesJobManagerFactory
- StandaloneKubernetesJobManagerParameters - Class in org.apache.flink.kubernetes.operator.kubeclient.parameters
-
A Utility class that helps to parse, verify and manage the Kubernetes parameters that are used for constructing the JobManager deployment used for standalone cluster deployments.
- StandaloneKubernetesJobManagerParameters(Configuration, ClusterSpecification) - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesJobManagerParameters
- StandaloneKubernetesTaskManagerFactory - Class in org.apache.flink.kubernetes.operator.kubeclient.factory
-
Utility class for constructing the TaskManager Deployment when deploying in standalone mode.
- StandaloneKubernetesTaskManagerFactory() - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.factory.StandaloneKubernetesTaskManagerFactory
- StandaloneKubernetesTaskManagerParameters - Class in org.apache.flink.kubernetes.operator.kubeclient.parameters
-
A utility class that helps to parse, verify and manage the Kubernetes parameters that are used for constructing the TaskManager deployment used for standalone deployments.
- StandaloneKubernetesTaskManagerParameters(Configuration, ClusterSpecification) - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.parameters.StandaloneKubernetesTaskManagerParameters
- StandaloneKubernetesUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Standalone Kubernetes Utils.
- StandaloneKubernetesUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.StandaloneKubernetesUtils
- start() - Method in class org.apache.flink.autoscaler.standalone.StandaloneAutoscalerExecutor
- start() - Method in class org.apache.flink.kubernetes.operator.health.OperatorHealthService
- STATE_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkStateSnapshotMetrics
- STATE_STORE_TYPE - Static variable in class org.apache.flink.autoscaler.standalone.config.AutoscalerStandaloneOptions
- STATELESS - org.apache.flink.kubernetes.operator.api.spec.UpgradeMode
-
Job is upgraded with empty state.
- STATELESS - org.apache.flink.kubernetes.operator.service.SuspendMode
- StateSnapshotObserver - Class in org.apache.flink.kubernetes.operator.observer.snapshot
-
The observer of
FlinkStateSnapshot
. - StateSnapshotObserver() - Constructor for class org.apache.flink.kubernetes.operator.observer.snapshot.StateSnapshotObserver
- StateSnapshotReconciler - Class in org.apache.flink.kubernetes.operator.reconciler.snapshot
-
The reconciler for the
FlinkStateSnapshot
. - StateSnapshotReconciler() - Constructor for class org.apache.flink.kubernetes.operator.reconciler.snapshot.StateSnapshotReconciler
- StateType - Enum in org.apache.flink.autoscaler.jdbc.state
-
The state type.
- STATUS_GROUP_NAME - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- statusCache - Variable in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
- StatusConflictException - Exception in org.apache.flink.kubernetes.operator.exception
-
Exception for status updates.
- StatusConflictException(String) - Constructor for exception org.apache.flink.kubernetes.operator.exception.StatusConflictException
- statusRecorder - Variable in class org.apache.flink.kubernetes.operator.reconciler.deployment.AbstractFlinkResourceReconciler
- StatusRecorder<CR extends io.fabric8.kubernetes.client.CustomResource<?,STATUS>,STATUS> - Class in org.apache.flink.kubernetes.operator.utils
-
Helper class for status management and updates.
- StatusRecorder(MetricManager<CR>, BiConsumer<CR, STATUS>) - Constructor for class org.apache.flink.kubernetes.operator.utils.StatusRecorder
- stop() - Method in class org.apache.flink.kubernetes.operator.FlinkOperator
- stop() - Method in class org.apache.flink.kubernetes.operator.health.HttpBootstrap
- stop() - Method in class org.apache.flink.kubernetes.operator.health.OperatorHealthService
- stopAndCleanupCluster(String) - Method in class org.apache.flink.kubernetes.operator.kubeclient.Fabric8FlinkStandaloneKubeClient
- storeCollectedMetrics(Context, SortedMap<Instant, CollectedMetrics>) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- storeCollectedMetrics(Context, SortedMap<Instant, CollectedMetrics>) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- storeCollectedMetrics(Context, SortedMap<Instant, CollectedMetrics>) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- storeCollectedMetrics(KubernetesJobAutoScalerContext, SortedMap<Instant, CollectedMetrics>) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- storeConfigChanges(Context, ConfigChanges) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- storeConfigChanges(Context, ConfigChanges) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- storeConfigChanges(Context, ConfigChanges) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- storeConfigChanges(KubernetesJobAutoScalerContext, ConfigChanges) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- storeDelayedScaleDown(Context, DelayedScaleDown) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- storeDelayedScaleDown(Context, DelayedScaleDown) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- storeDelayedScaleDown(Context, DelayedScaleDown) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- storeDelayedScaleDown(KubernetesJobAutoScalerContext, DelayedScaleDown) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- storeParallelismOverrides(Context, Map<String, String>) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- storeParallelismOverrides(Context, Map<String, String>) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- storeParallelismOverrides(Context, Map<String, String>) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- storeParallelismOverrides(KubernetesJobAutoScalerContext, Map<String, String>) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- storeScalingHistory(Context, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- storeScalingHistory(Context, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- storeScalingHistory(Context, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- storeScalingHistory(KubernetesJobAutoScalerContext, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- storeScalingTracking(Context, ScalingTracking) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- storeScalingTracking(Context, ScalingTracking) - Method in interface org.apache.flink.autoscaler.state.AutoScalerStateStore
- storeScalingTracking(Context, ScalingTracking) - Method in class org.apache.flink.autoscaler.state.InMemoryAutoScalerStateStore
- storeScalingTracking(KubernetesJobAutoScalerContext, ScalingTracking) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- Submit - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- submitApplicationCluster(JobSpec, Configuration, boolean) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- submitApplicationCluster(JobSpec, Configuration, boolean) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- submitClusterInternal(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- submitClusterInternal(Configuration, Mode) - Method in class org.apache.flink.kubernetes.operator.service.StandaloneFlinkService
- submitJobToSessionCluster(ObjectMeta, FlinkSessionJobSpec, JobID, Configuration, String) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- submitJobToSessionCluster(ObjectMeta, FlinkSessionJobSpec, JobID, Configuration, String) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- submitSessionCluster(Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- submitSessionCluster(Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- SUCCEEDED - org.apache.flink.kubernetes.operator.utils.SnapshotStatus
-
Snapshot is completed successfully.
- Suspended - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- SUSPENDED - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- SUSPENDED - org.apache.flink.kubernetes.operator.api.spec.JobState
-
Processing is suspended with the intention of continuing later.
- SuspendMode - Enum in org.apache.flink.kubernetes.operator.service
-
Suspend mode.
- synchronizedCounter(Counter) - Static method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils
- SynchronizedCounter(Counter) - Constructor for class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedCounter
- SynchronizedHistogram(Histogram) - Constructor for class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedHistogram
- synchronizedMeterView(MeterView) - Static method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils
- SynchronizedMeterView(MeterView) - Constructor for class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedMeterView
T
- TARGET_DATA_RATE - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Target processing rate of operators as derived from source inputs (records/sec).
- TARGET_UTILIZATION - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- TARGET_UTILIZATION_BOUNDARY - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- TASKMANAGER_ENTRYPOINT_ARG - Static variable in class org.apache.flink.kubernetes.operator.kubeclient.decorators.CmdStandaloneTaskManagerDecorator
- TaskManagerInfo - Class in org.apache.flink.kubernetes.operator.api.status
-
Last observed status of the Flink job within an application deployment.
- TaskManagerInfo() - Constructor for class org.apache.flink.kubernetes.operator.api.status.TaskManagerInfo
- TaskManagerSpec - Class in org.apache.flink.kubernetes.operator.api.spec
-
TaskManager spec.
- TaskManagerSpec() - Constructor for class org.apache.flink.kubernetes.operator.api.spec.TaskManagerSpec
- timeControllerExecution(Metrics.ControllerExecution<T>) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorJosdkMetrics
- to - Variable in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics.Transition
- toErrorStatusUpdateControl(FlinkResourceContext<R>, Exception, StatusRecorder<R, STATUS>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
Update the resource error status and metrics when the operator encountered an exception during reconciliation.
- toJobStatusMessage(JobDetails) - Static method in class org.apache.flink.autoscaler.utils.JobStatusUtils
- toJobStatusMessage(MultipleJobsDetails) - Static method in class org.apache.flink.autoscaler.utils.JobStatusUtils
- toString() - Method in class org.apache.flink.autoscaler.JobVertexScaler.ParallelismChange
- toString() - Method in class org.apache.flink.kubernetes.operator.api.spec.JobReference
- toString() - Method in class org.apache.flink.kubernetes.operator.reconciler.diff.DiffResult
- toString() - Method in class org.apache.flink.kubernetes.operator.resources.ClusterResourceView
- toString() - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesNodeResourceInfo
- toString() - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesResource
- toString() - Method in class org.apache.flink.runtime.rest.messages.job.metrics.AggregatedMetric
- TOTAL_GC_TIME_PER_SEC - org.apache.flink.autoscaler.metrics.FlinkMetric
- toUpdateControl(FlinkOperatorConfiguration, R, R, boolean) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- TRACKED_RESTART_TIME_LIMIT - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- TRACKED_TRANSITIONS - Static variable in class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics
- Transition() - Constructor for class org.apache.flink.kubernetes.operator.metrics.lifecycle.LifecycleMetrics.Transition
- TRIGGER_PENDING - org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus.State
-
Not yet processed by the operator.
- triggerCheckpoint(String, CheckpointType, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- triggerCheckpoint(String, CheckpointType, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- triggerEvent(AbstractFlinkResource<?, ?>, EventRecorder.Type, String, String, EventRecorder.Component, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerEvent(AbstractFlinkResource<?, ?>, EventRecorder.Type, String, String, EventRecorder.Component, String, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerEvent(AbstractFlinkResource<?, ?>, EventRecorder.Type, EventRecorder.Reason, String, EventRecorder.Component, String, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerEvent(AbstractFlinkResource<?, ?>, EventRecorder.Type, EventRecorder.Reason, EventRecorder.Component, String, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerEventOnce(AbstractFlinkResource<?, ?>, EventRecorder.Type, String, String, EventRecorder.Component, String, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerEventOnce(AbstractFlinkResource<?, ?>, EventRecorder.Type, EventRecorder.Reason, String, EventRecorder.Component, String, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerEventWithInterval(AbstractFlinkResource<?, ?>, EventRecorder.Type, String, String, EventRecorder.Component, String, KubernetesClient, Duration) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerEventWithLabels(AbstractFlinkResource<?, ?>, EventRecorder.Type, String, String, EventRecorder.Component, String, KubernetesClient, Duration, Predicate<Map<String, String>>, Map<String, String>) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- triggerSavepoint(String, SavepointFormatType, String, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- triggerSavepoint(String, SavepointFormatType, String, Configuration) - Method in interface org.apache.flink.kubernetes.operator.service.FlinkService
- triggerSnapshotEvent(FlinkStateSnapshot, EventRecorder.Type, EventRecorder.Reason, EventRecorder.Component, String, KubernetesClient) - Method in class org.apache.flink.kubernetes.operator.utils.EventRecorder
- trimHistoryToMaxCmSize(KubernetesJobAutoScalerContext) - Method in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
- trimScalingHistory(Instant, Configuration, Map<JobVertexID, SortedMap<Instant, ScalingSummary>>) - Static method in class org.apache.flink.autoscaler.metrics.ScalingHistoryUtils
- TRUE_PROCESSING_RATE - org.apache.flink.autoscaler.metrics.ScalingMetric
-
Processing rate at full capacity (records/sec).
- tryRelease(double, double) - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesNodeResourceInfo
- tryReserve(double, MemorySize) - Method in class org.apache.flink.kubernetes.operator.resources.ClusterResourceView
- tryReserve(double, MemorySize) - Method in class org.apache.flink.kubernetes.operator.resources.KubernetesNodeResourceInfo
- trySchedule(int, int, double, MemorySize) - Method in class org.apache.flink.autoscaler.resources.NoopResourceCheck
- trySchedule(int, int, double, MemorySize) - Method in interface org.apache.flink.autoscaler.resources.ResourceCheck
-
Simulates scheduling the provided number of TaskManager instances.
- trySchedule(int, int, double, MemorySize) - Method in class org.apache.flink.kubernetes.operator.resources.ClusterResourceManager
- tuneTaskManagerMemory(JobAutoScalerContext<?>, EvaluatedMetrics, JobTopology, Map<JobVertexID, ScalingSummary>, AutoScalerEventHandler) - Static method in class org.apache.flink.autoscaler.tuning.MemoryTuning
-
Emits a Configuration which contains overrides for the current configuration.
- type() - Method in annotation type org.apache.flink.kubernetes.operator.api.diff.SpecDiff.Entry
U
- UNKNOWN - org.apache.flink.autoscaler.topology.ShipStrategy
- UNKNOWN - org.apache.flink.kubernetes.operator.api.status.CheckpointType
-
Checkpoint format unknown, if the checkpoint was not triggered by the operator.
- UNKNOWN - org.apache.flink.kubernetes.operator.api.status.SavepointFormatType
-
Savepoint format unknown, if the savepoint was not triggered by the operator.
- UNKNOWN - org.apache.flink.kubernetes.operator.api.status.SnapshotTriggerType
-
Snapshot trigger mechanism unknown, such as savepoint retrieved directly from Flink job.
- UNKNOWN_VERSION - Static variable in class org.apache.flink.kubernetes.operator.metrics.FlinkDeploymentMetrics
- UnsupportedFlinkVersion - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- update() - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedMeterView
- update(long) - Method in class org.apache.flink.kubernetes.operator.metrics.OperatorMetricUtils.SynchronizedHistogram
- updateData(String, List<StateType>, Map<StateType, String>) - Method in class org.apache.flink.autoscaler.jdbc.state.JdbcStateInteractor
- updateDefaultConfig(Configuration) - Method in class org.apache.flink.kubernetes.operator.config.FlinkConfigManager
-
Update the base configuration for the operator.
- updateErrorStatus(FlinkDeployment, Context<FlinkDeployment>, Exception) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkDeploymentController
- updateErrorStatus(FlinkSessionJob, Context<FlinkSessionJob>, Exception) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkSessionJobController
- updateErrorStatus(FlinkStateSnapshot, Context<FlinkStateSnapshot>, Exception) - Method in class org.apache.flink.kubernetes.operator.controller.FlinkStateSnapshotController
- updateEvent(long, String, int) - Method in class org.apache.flink.autoscaler.jdbc.event.JdbcEventInteractor
- updateFlinkResourceException(Throwable, R, FlinkOperatorConfiguration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkResourceExceptionUtils
- updateFlinkStateSnapshotException(Throwable, FlinkStateSnapshot, FlinkOperatorConfiguration) - Static method in class org.apache.flink.kubernetes.operator.utils.FlinkResourceExceptionUtils
- updateForReconciliationError(FlinkResourceContext<?>, Throwable) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateForReconciliationError(FlinkStateSnapshotContext, Throwable) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateIngressRules(ObjectMeta, FlinkDeploymentSpec, Configuration, KubernetesClient) - Static method in class org.apache.flink.kubernetes.operator.utils.IngressUtils
- updateLastCheckpoint(Checkpoint) - Method in class org.apache.flink.kubernetes.operator.api.status.CheckpointInfo
-
Deprecated.Update last checkpoint info.
- updateLastPeriodicTriggerTimestamp(HasMetadata, SnapshotType, Instant) - Method in class org.apache.flink.kubernetes.operator.reconciler.SnapshotTriggerTimestampStore
-
Updates the time a periodic snapshot was last triggered for this resource.
- updateLastReconciledSnapshotTriggerNonce(SnapshotTriggerType, AbstractFlinkResource<SPEC, ?>, SnapshotType) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateLastReconciledSpec(AbstractFlinkResource<T, ?>, BiConsumer<T, ReconciliationMetadata>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateLastSavepoint(Savepoint) - Method in class org.apache.flink.kubernetes.operator.api.status.SavepointInfo
-
Deprecated.Update last savepoint info and add the savepoint to the history if it isn't already the most recent savepoint.
- updateMetrics(Context, AutoScalerStateStore<KEY, Context>) - Method in class org.apache.flink.autoscaler.ScalingMetricCollector
- updateReconciliationMetadata(AbstractFlinkResource<SPEC, ?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateStatusAfterClusterDeletion(FlinkDeploymentStatus) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- updateStatusBeforeDeploymentAttempt(AbstractFlinkResource<SPEC, ?>, Configuration) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateStatusBeforeDeploymentAttempt(AbstractFlinkResource<SPEC, ?>, Configuration, Clock) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
Update status before deployment attempt of a new resource spec.
- updateStatusForAlreadyUpgraded(AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
Updates status in cases where a previously successful deployment wasn't recorded for any reason.
- updateStatusForDeployedSpec(AbstractFlinkResource<SPEC, ?>, Configuration) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateStatusForDeployedSpec(AbstractFlinkResource<SPEC, ?>, Configuration, Clock) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
-
Update status after successful deployment of a new resource spec.
- updateStatusForSpecReconciliation(AbstractFlinkResource<SPEC, ?>, JobState, Configuration, boolean, Clock) - Static method in class org.apache.flink.kubernetes.operator.reconciler.ReconciliationUtils
- updateStatusFromCache(CR) - Method in class org.apache.flink.kubernetes.operator.utils.StatusRecorder
-
Update the custom resource status based on the in-memory cached to ensure that any status updates that we made previously are always visible in the reconciliation loop.
- updateVertexList(AutoScalerStateStore<KEY, Context>, Context, Instant, Set<JobVertexID>) - Static method in class org.apache.flink.autoscaler.metrics.ScalingHistoryUtils
- updateVertexResources(RestClusterClient<String>, AbstractFlinkResource<?, ?>, Map<JobVertexID, JobVertexResourceRequirements>) - Method in class org.apache.flink.kubernetes.operator.service.NativeFlinkService
- UPGRADE - org.apache.flink.kubernetes.operator.api.diff.DiffType
-
Upgradable spec change.
- UPGRADE - org.apache.flink.kubernetes.operator.api.status.SnapshotTriggerType
-
Snapshot triggered during stateful upgrade.
- UpgradeFailureException - Exception in org.apache.flink.kubernetes.operator.exception
-
Exception to signal non-terminal deployment failure.
- UpgradeFailureException(String, String) - Constructor for exception org.apache.flink.kubernetes.operator.exception.UpgradeFailureException
- UpgradeFailureException(String, String, Throwable) - Constructor for exception org.apache.flink.kubernetes.operator.exception.UpgradeFailureException
- UpgradeMode - Enum in org.apache.flink.kubernetes.operator.api.spec
-
Enum to control Flink job upgrade behavior.
- UPGRADING - org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
- UPGRADING - org.apache.flink.kubernetes.operator.api.status.ReconciliationState
-
The spec is being upgraded.
- uploadJar(ObjectMeta, FlinkSessionJobSpec, Configuration) - Method in class org.apache.flink.kubernetes.operator.service.AbstractFlinkService
- URL - Static variable in class org.apache.flink.kubernetes.operator.service.CustomCheckpointingStatisticsHeaders
- UserLibMountDecorator - Class in org.apache.flink.kubernetes.operator.kubeclient.decorators
-
Mount the Flink User Lib directory to enable Flink to pick up a Jars defined in pipeline.classpaths.
- UserLibMountDecorator(StandaloneKubernetesJobManagerParameters) - Constructor for class org.apache.flink.kubernetes.operator.kubeclient.decorators.UserLibMountDecorator
- Utils - Class in org.apache.flink.kubernetes.operator.docs.util
-
Contains various shared utility functions.
- Utils() - Constructor for class org.apache.flink.kubernetes.operator.docs.util.Utils
V
- v1_13 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
-
Deprecated.
- v1_14 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
-
Deprecated.
- v1_15 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
-
Deprecated.
- v1_16 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
- v1_17 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
- v1_18 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
- v1_19 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
- v1_20 - org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
- validate(HasMetadata, Operation) - Method in class org.apache.flink.kubernetes.operator.admission.FlinkValidator
- VALIDATE_REQUEST_PATH - Static variable in class org.apache.flink.kubernetes.operator.admission.AdmissionHandler
- validateAutoScalerFlinkConfiguration(Map<String, String>) - Static method in class org.apache.flink.kubernetes.operator.validation.DefaultValidator
- validateDeployment(FlinkDeployment) - Method in class org.apache.flink.kubernetes.operator.validation.DefaultValidator
- validateDeployment(FlinkDeployment) - Method in interface org.apache.flink.kubernetes.operator.validation.FlinkResourceValidator
-
Validate and return optional error.
- validateExcludedPeriods(Configuration) - Static method in class org.apache.flink.autoscaler.utils.CalendarUtils
- validateSessionJob(FlinkSessionJob, Optional<FlinkDeployment>) - Method in class org.apache.flink.kubernetes.operator.validation.DefaultValidator
- validateSessionJob(FlinkSessionJob, Optional<FlinkDeployment>) - Method in interface org.apache.flink.kubernetes.operator.validation.FlinkResourceValidator
-
Validate and return optional error.
- validateStateSnapshot(FlinkStateSnapshot, Optional<AbstractFlinkResource<?, ?>>) - Method in class org.apache.flink.kubernetes.operator.validation.DefaultValidator
- validateStateSnapshot(FlinkStateSnapshot, Optional<AbstractFlinkResource<?, ?>>) - Method in interface org.apache.flink.kubernetes.operator.validation.FlinkResourceValidator
-
Validate and return optional error.
- validateSupportedVersion(FlinkResourceContext<?>, EventRecorder) - Static method in class org.apache.flink.kubernetes.operator.utils.ValidatorUtils
- ValidationError - org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
- ValidationException - Exception in org.apache.flink.kubernetes.operator.exception
-
Exception to signal validation failure.
- ValidationException(String) - Constructor for exception org.apache.flink.kubernetes.operator.exception.ValidationException
- ValidationException(String, Throwable) - Constructor for exception org.apache.flink.kubernetes.operator.exception.ValidationException
- ValidationException(Throwable) - Constructor for exception org.apache.flink.kubernetes.operator.exception.ValidationException
- ValidatorUtils - Class in org.apache.flink.kubernetes.operator.utils
-
Validator utilities.
- ValidatorUtils() - Constructor for class org.apache.flink.kubernetes.operator.utils.ValidatorUtils
- value() - Method in annotation type org.apache.flink.kubernetes.operator.api.diff.SpecDiff.Config
- value() - Method in annotation type org.apache.flink.kubernetes.operator.api.diff.SpecDiff
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.event.AutoScalerEventHandler.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.jdbc.state.StateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.JobVertexScaler.ParallelismChangeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.metrics.FlinkMetric
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.metrics.MetricAggregator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.metrics.ScalingMetric
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.standalone.AutoscalerEventHandlerFactory.EventHandlerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.standalone.AutoscalerStateStoreFactory.StateStoreType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.autoscaler.topology.ShipStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.diff.DiffType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.JobKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.JobState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.KubernetesDeploymentMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.spec.UpgradeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.status.CheckpointType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.status.JobManagerDeploymentStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.status.ReconciliationState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.status.SavepointFormatType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.api.status.SnapshotTriggerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.config.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.health.HealthProbe
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.reconciler.SnapshotType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.service.SuspendMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.standalone.StandaloneKubernetesConfigOptionsInternal.ClusterMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.utils.EventRecorder.Component
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.utils.EventRecorder.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.kubernetes.operator.utils.SnapshotStatus
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.flink.autoscaler.event.AutoScalerEventHandler.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.jdbc.state.StateType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.JobVertexScaler.ParallelismChangeType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.metrics.FlinkMetric
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.metrics.MetricAggregator
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.metrics.ScalingMetric
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.standalone.AutoscalerEventHandlerFactory.EventHandlerType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.standalone.AutoscalerStateStoreFactory.StateStoreType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.autoscaler.topology.ShipStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.diff.DiffType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.lifecycle.ResourceLifecycleState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.spec.FlinkVersion
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.spec.JobKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.spec.JobState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.spec.KubernetesDeploymentMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.spec.UpgradeMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.status.CheckpointType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.status.FlinkStateSnapshotStatus.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.status.JobManagerDeploymentStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.status.ReconciliationState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.status.SavepointFormatType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.api.status.SnapshotTriggerType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.config.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.health.HealthProbe
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.reconciler.SnapshotType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.service.SuspendMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.standalone.StandaloneKubernetesConfigOptionsInternal.ClusterMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.utils.EventRecorder.Component
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.utils.EventRecorder.Reason
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.utils.EventRecorder.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.kubernetes.operator.utils.SnapshotStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- verifyOtherPropsMatch(String, JsonNode, JsonNode) - Static method in class org.apache.flink.kubernetes.operator.api.validation.CrdCompatibilityChecker
- VERSION_CONF_PREFIX - Static variable in class org.apache.flink.kubernetes.operator.config.KubernetesOperatorConfigOptions
- VERTEX_EXCLUDE_IDS - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- VERTEX_MAX_PARALLELISM - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- VERTEX_MIN_PARALLELISM - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- VERTEX_SCALING_HISTORY_AGE - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- VERTEX_SCALING_HISTORY_COUNT - Static variable in class org.apache.flink.autoscaler.config.AutoScalerOptions
- VertexInfo - Class in org.apache.flink.autoscaler.topology
-
Job vertex information.
- VertexInfo(JobVertexID, Map<JobVertexID, ShipStrategy>, int, int) - Constructor for class org.apache.flink.autoscaler.topology.VertexInfo
- VertexInfo(JobVertexID, Map<JobVertexID, ShipStrategy>, int, int, boolean, IOMetrics) - Constructor for class org.apache.flink.autoscaler.topology.VertexInfo
- VertexInfo(JobVertexID, Map<JobVertexID, ShipStrategy>, int, int, IOMetrics) - Constructor for class org.apache.flink.autoscaler.topology.VertexInfo
- VertexInfo(JobVertexID, SlotSharingGroupId, Map<JobVertexID, ShipStrategy>, int, int, boolean, IOMetrics) - Constructor for class org.apache.flink.autoscaler.topology.VertexInfo
- VertexScalingReport - Class in org.apache.flink.autoscaler.event
-
The scaling report of single vertex.
- VertexScalingReport() - Constructor for class org.apache.flink.autoscaler.event.VertexScalingReport
W
- Warning - org.apache.flink.autoscaler.event.AutoScalerEventHandler.Type
- Warning - org.apache.flink.kubernetes.operator.utils.EventRecorder.Type
- writeSpecWithMeta(AbstractFlinkSpec, AbstractFlinkResource<?, ?>) - Static method in class org.apache.flink.kubernetes.operator.api.utils.SpecUtils
-
Serializes the spec and custom meta information into a JSON string.
- writeSpecWithMeta(AbstractFlinkSpec, ReconciliationMetadata) - Static method in class org.apache.flink.kubernetes.operator.api.utils.SpecUtils
-
Serializes the spec and custom meta information into a JSON string.
Y
- YAML_MAPPER - Static variable in class org.apache.flink.autoscaler.jdbc.state.JdbcAutoScalerStateStore
- YAML_MAPPER - Static variable in class org.apache.flink.kubernetes.operator.autoscaler.state.KubernetesAutoScalerStateStore
All Classes All Packages