Key Default Type Description
kubernetes.operator.dynamic.namespaces.enabled
false Boolean Enables dynamic change of watched/monitored namespaces.
kubernetes.operator.exception.field.max.length
2048 Integer Maximum length of each exception field including stack trace to be included in CR status error field.
kubernetes.operator.exception.stacktrace.enabled
false Boolean Enable exception stacktrace to be included in CR status error field.
kubernetes.operator.exception.stacktrace.max.length
2048 Integer Maximum length of stacktrace to be included in CR status error field.
kubernetes.operator.exception.throwable.list.max.count
2 Integer Maximum number of throwable to be included in CR status error field.
kubernetes.operator.flink.client.cancel.timeout
1 min Duration The timeout for the reconciler to wait for flink to cancel job.
kubernetes.operator.flink.client.timeout
10 s Duration The timeout for the observer to wait the flink rest client to return.
kubernetes.operator.leader-election.enabled
false Boolean Enable leader election for the operator to allow running standby instances.
kubernetes.operator.leader-election.lease-duration
15 s Duration Leader election lease duration.
kubernetes.operator.leader-election.lease-name
(none) String Leader election lease name, must be unique for leases in the same namespace.
kubernetes.operator.leader-election.renew-deadline
10 s Duration Leader election renew deadline.
kubernetes.operator.leader-election.retry-period
2 s Duration Leader election retry period.
kubernetes.operator.reconcile.interval
1 min Duration The interval for the controller to reschedule the reconcile process.
kubernetes.operator.reconcile.parallelism
200 Integer The maximum number of threads running the reconciliation loop. Use -1 for infinite.
kubernetes.operator.resource.cleanup.timeout
1 min Duration The timeout for the resource clean up to wait for flink to shutdown cluster.
kubernetes.operator.retry.initial.interval
5 s Duration Initial interval of automatic reconcile retries on recoverable errors.
kubernetes.operator.retry.interval.multiplier
2.0 Double Interval multiplier of automatic reconcile retries on recoverable errors.
kubernetes.operator.retry.max.attempts
10 Integer Max attempts of automatic reconcile retries on recoverable errors.
kubernetes.operator.user.artifacts.base.dir
"/opt/flink/artifacts" String The base dir to put the session job artifacts.
kubernetes.operator.watched.namespaces
"JOSDK_ALL_NAMESPACES" String Comma separated list of namespaces the operator monitors for custom resources.