2023-08-23 11:35:12 -04:00
// Copyright (c) Tailscale Inc & AUTHORS
// SPDX-License-Identifier: BSD-3-Clause
2023-08-24 15:02:42 -07:00
//go:build !plan9
2023-08-23 11:35:12 -04:00
package main
import (
"context"
2024-06-18 19:01:40 +01:00
"errors"
2023-08-23 11:35:12 -04:00
"fmt"
2023-10-03 19:12:37 -07:00
"slices"
2023-08-23 11:35:12 -04:00
"strings"
2023-08-30 09:49:11 -07:00
"sync"
2023-08-23 11:35:12 -04:00
"go.uber.org/zap"
corev1 "k8s.io/api/core/v1"
2024-06-18 19:01:40 +01:00
apiequality "k8s.io/apimachinery/pkg/api/equality"
2023-08-23 11:35:12 -04:00
apierrors "k8s.io/apimachinery/pkg/api/errors"
2024-06-18 19:01:40 +01:00
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
2023-08-30 09:49:11 -07:00
"k8s.io/apimachinery/pkg/types"
2023-10-17 18:05:02 +01:00
"k8s.io/client-go/tools/record"
2023-08-23 11:35:12 -04:00
"sigs.k8s.io/controller-runtime/pkg/client"
"sigs.k8s.io/controller-runtime/pkg/reconcile"
2024-02-13 05:27:54 +00:00
tsoperator "tailscale.com/k8s-operator"
tsapi "tailscale.com/k8s-operator/apis/v1alpha1"
2024-04-19 16:49:46 +01:00
"tailscale.com/net/dns/resolvconffile"
2024-06-18 19:01:40 +01:00
"tailscale.com/tstime"
2023-08-30 09:49:11 -07:00
"tailscale.com/util/clientmetric"
2024-06-18 19:01:40 +01:00
"tailscale.com/util/dnsname"
2023-08-30 09:49:11 -07:00
"tailscale.com/util/set"
2023-08-23 11:35:12 -04:00
)
2024-04-19 16:49:46 +01:00
const (
resolvConfPath = "/etc/resolv.conf"
defaultClusterDomain = "cluster.local"
2024-06-18 19:01:40 +01:00
reasonProxyCreated = "ProxyCreated"
reasonProxyInvalid = "ProxyInvalid"
reasonProxyFailed = "ProxyFailed"
reasonProxyPending = "ProxyPending"
2024-04-19 16:49:46 +01:00
)
2023-08-23 11:35:12 -04:00
type ServiceReconciler struct {
client . Client
2023-08-17 02:35:36 +02:00
ssr * tailscaleSTSReconciler
logger * zap . SugaredLogger
isDefaultLoadBalancer bool
2023-08-30 09:49:11 -07:00
mu sync . Mutex // protects following
// managedIngressProxies is a set of all ingress proxies that we're
// currently managing. This is only used for metrics.
managedIngressProxies set . Slice [ types . UID ]
// managedEgressProxies is a set of all egress proxies that we're currently
// managing. This is only used for metrics.
managedEgressProxies set . Slice [ types . UID ]
2023-10-17 18:05:02 +01:00
recorder record . EventRecorder
2024-04-19 16:49:46 +01:00
tsNamespace string
2024-06-18 19:01:40 +01:00
clock tstime . Clock
2024-08-20 10:50:40 -04:00
proxyDefaultClass string
2023-08-23 11:35:12 -04:00
}
2023-08-30 09:49:11 -07:00
var (
// gaugeEgressProxies tracks the number of egress proxies that we're
// currently managing.
gaugeEgressProxies = clientmetric . NewGauge ( "k8s_egress_proxies" )
// gaugeIngressProxies tracks the number of ingress proxies that we're
// currently managing.
gaugeIngressProxies = clientmetric . NewGauge ( "k8s_ingress_proxies" )
)
2023-08-24 15:18:17 -04:00
func childResourceLabels ( name , ns , typ string ) map [ string ] string {
2023-08-23 11:35:12 -04:00
// You might wonder why we're using owner references, since they seem to be
// built for exactly this. Unfortunately, Kubernetes does not support
// cross-namespace ownership, by design. This means we cannot make the
// service being exposed the owner of the implementation details of the
// proxying. Instead, we have to do our own filtering and tracking with
// labels.
return map [ string ] string {
LabelManaged : "true" ,
2023-08-24 15:18:17 -04:00
LabelParentName : name ,
LabelParentNamespace : ns ,
LabelParentType : typ ,
2023-08-23 11:35:12 -04:00
}
}
2024-06-18 19:01:40 +01:00
func ( a * ServiceReconciler ) isTailscaleService ( svc * corev1 . Service ) bool {
targetIP := tailnetTargetAnnotation ( svc )
targetFQDN := svc . Annotations [ AnnotationTailnetTargetFQDN ]
return a . shouldExpose ( svc ) || targetIP != "" || targetFQDN != ""
}
2023-08-23 11:35:12 -04:00
func ( a * ServiceReconciler ) Reconcile ( ctx context . Context , req reconcile . Request ) ( _ reconcile . Result , err error ) {
logger := a . logger . With ( "service-ns" , req . Namespace , "service-name" , req . Name )
logger . Debugf ( "starting reconcile" )
defer logger . Debugf ( "reconcile finished" )
svc := new ( corev1 . Service )
err = a . Get ( ctx , req . NamespacedName , svc )
if apierrors . IsNotFound ( err ) {
// Request object not found, could have been deleted after reconcile request.
logger . Debugf ( "service not found, assuming it was deleted" )
return reconcile . Result { } , nil
} else if err != nil {
return reconcile . Result { } , fmt . Errorf ( "failed to get svc: %w" , err )
}
2024-06-18 19:01:40 +01:00
if ! svc . DeletionTimestamp . IsZero ( ) || ! a . isTailscaleService ( svc ) {
2023-08-30 08:31:37 +01:00
logger . Debugf ( "service is being deleted or is (no longer) referring to Tailscale ingress/egress, ensuring any created resources are cleaned up" )
2023-08-23 11:35:12 -04:00
return reconcile . Result { } , a . maybeCleanup ( ctx , logger , svc )
}
return reconcile . Result { } , a . maybeProvision ( ctx , logger , svc )
}
// maybeCleanup removes any existing resources related to serving svc over tailscale.
//
// This function is responsible for removing the finalizer from the service,
// once all associated resources are gone.
2024-06-18 19:01:40 +01:00
func ( a * ServiceReconciler ) maybeCleanup ( ctx context . Context , logger * zap . SugaredLogger , svc * corev1 . Service ) ( err error ) {
oldSvcStatus := svc . Status . DeepCopy ( )
defer func ( ) {
if ! apiequality . Semantic . DeepEqual ( oldSvcStatus , svc . Status ) {
// An error encountered here should get returned by the Reconcile function.
err = errors . Join ( err , a . Client . Status ( ) . Update ( ctx , svc ) )
}
} ( )
2023-08-23 11:35:12 -04:00
ix := slices . Index ( svc . Finalizers , FinalizerName )
if ix < 0 {
logger . Debugf ( "no finalizer, nothing to do" )
2023-08-30 09:49:11 -07:00
a . mu . Lock ( )
defer a . mu . Unlock ( )
a . managedIngressProxies . Remove ( svc . UID )
a . managedEgressProxies . Remove ( svc . UID )
gaugeIngressProxies . Set ( int64 ( a . managedIngressProxies . Len ( ) ) )
gaugeEgressProxies . Set ( int64 ( a . managedEgressProxies . Len ( ) ) )
2024-06-18 19:01:40 +01:00
if ! a . isTailscaleService ( svc ) {
tsoperator . RemoveServiceCondition ( svc , tsapi . ProxyReady )
}
2023-08-23 11:35:12 -04:00
return nil
}
2023-08-24 15:18:17 -04:00
if done , err := a . ssr . Cleanup ( ctx , logger , childResourceLabels ( svc . Name , svc . Namespace , "svc" ) ) ; err != nil {
2023-08-23 11:35:12 -04:00
return fmt . Errorf ( "failed to cleanup: %w" , err )
} else if ! done {
logger . Debugf ( "cleanup not done yet, waiting for next reconcile" )
return nil
}
svc . Finalizers = append ( svc . Finalizers [ : ix ] , svc . Finalizers [ ix + 1 : ] ... )
if err := a . Update ( ctx , svc ) ; err != nil {
return fmt . Errorf ( "failed to remove finalizer: %w" , err )
}
// Unlike most log entries in the reconcile loop, this will get printed
// exactly once at the very end of cleanup, because the final step of
// cleanup removes the tailscale finalizer, which will make all future
// reconciles exit early.
2024-06-18 19:01:40 +01:00
logger . Infof ( "unexposed Service from tailnet" )
2023-08-30 09:49:11 -07:00
a . mu . Lock ( )
defer a . mu . Unlock ( )
a . managedIngressProxies . Remove ( svc . UID )
a . managedEgressProxies . Remove ( svc . UID )
gaugeIngressProxies . Set ( int64 ( a . managedIngressProxies . Len ( ) ) )
gaugeEgressProxies . Set ( int64 ( a . managedEgressProxies . Len ( ) ) )
2024-06-18 19:01:40 +01:00
if ! a . isTailscaleService ( svc ) {
tsoperator . RemoveServiceCondition ( svc , tsapi . ProxyReady )
}
2023-08-23 11:35:12 -04:00
return nil
}
// maybeProvision ensures that svc is exposed over tailscale, taking any actions
// necessary to reach that state.
//
// This function adds a finalizer to svc, ensuring that we can handle orderly
// deprovisioning later.
2024-06-18 19:01:40 +01:00
func ( a * ServiceReconciler ) maybeProvision ( ctx context . Context , logger * zap . SugaredLogger , svc * corev1 . Service ) ( err error ) {
oldSvcStatus := svc . Status . DeepCopy ( )
defer func ( ) {
if ! apiequality . Semantic . DeepEqual ( oldSvcStatus , svc . Status ) {
// An error encountered here should get returned by the Reconcile function.
err = errors . Join ( err , a . Client . Status ( ) . Update ( ctx , svc ) )
}
} ( )
2023-11-24 16:24:48 +00:00
// Run for proxy config related validations here as opposed to running
// them earlier. This is to prevent cleanup being blocked on a
// misconfigured proxy param.
2023-10-17 18:05:02 +01:00
if err := a . ssr . validate ( ) ; err != nil {
msg := fmt . Sprintf ( "unable to provision proxy resources: invalid config: %v" , err )
a . recorder . Event ( svc , corev1 . EventTypeWarning , "INVALIDCONFIG" , msg )
a . logger . Error ( msg )
2024-06-18 19:01:40 +01:00
tsoperator . SetServiceCondition ( svc , tsapi . ProxyReady , metav1 . ConditionFalse , reasonProxyInvalid , msg , a . clock , logger )
2023-10-17 18:05:02 +01:00
return nil
}
2023-11-24 16:24:48 +00:00
if violations := validateService ( svc ) ; len ( violations ) > 0 {
msg := fmt . Sprintf ( "unable to provision proxy resources: invalid Service: %s" , strings . Join ( violations , ", " ) )
2024-05-22 09:59:52 -04:00
a . recorder . Event ( svc , corev1 . EventTypeWarning , "INVALIDSERVICE" , msg )
2023-11-24 16:24:48 +00:00
a . logger . Error ( msg )
2024-06-18 19:01:40 +01:00
tsoperator . SetServiceCondition ( svc , tsapi . ProxyReady , metav1 . ConditionFalse , reasonProxyInvalid , msg , a . clock , logger )
2023-11-24 16:24:48 +00:00
return nil
}
2024-02-13 05:27:54 +00:00
2024-08-20 10:50:40 -04:00
proxyClass := proxyClassForObject ( svc , a . proxyDefaultClass )
2024-02-13 05:27:54 +00:00
if proxyClass != "" {
if ready , err := proxyClassIsReady ( ctx , proxyClass , a . Client ) ; err != nil {
2024-06-18 19:01:40 +01:00
errMsg := fmt . Errorf ( "error verifying ProxyClass for Service: %w" , err )
tsoperator . SetServiceCondition ( svc , tsapi . ProxyReady , metav1 . ConditionFalse , reasonProxyFailed , errMsg . Error ( ) , a . clock , logger )
return errMsg
2024-02-13 05:27:54 +00:00
} else if ! ready {
2024-06-18 19:01:40 +01:00
msg := fmt . Sprintf ( "ProxyClass %s specified for the Service, but is not (yet) Ready, waiting.." , proxyClass )
tsoperator . SetServiceCondition ( svc , tsapi . ProxyReady , metav1 . ConditionFalse , reasonProxyPending , msg , a . clock , logger )
logger . Info ( msg )
2024-02-13 05:27:54 +00:00
return nil
}
}
2023-08-23 11:35:12 -04:00
if ! slices . Contains ( svc . Finalizers , FinalizerName ) {
// This log line is printed exactly once during initial provisioning,
// because once the finalizer is in place this block gets skipped. So,
// this is a nice place to tell the operator that the high level,
// multi-reconcile operation is underway.
logger . Infof ( "exposing service over tailscale" )
svc . Finalizers = append ( svc . Finalizers , FinalizerName )
if err := a . Update ( ctx , svc ) ; err != nil {
2024-06-18 19:01:40 +01:00
errMsg := fmt . Errorf ( "failed to add finalizer: %w" , err )
tsoperator . SetServiceCondition ( svc , tsapi . ProxyReady , metav1 . ConditionFalse , reasonProxyFailed , errMsg . Error ( ) , a . clock , logger )
return errMsg
2023-08-23 11:35:12 -04:00
}
}
2024-08-29 13:25:13 +03:00
// crl := childResourceLabels(svc.Name, svc.Namespace, "svc")
// var tags []string
// if tstr, ok := svc.Annotations[AnnotationTags]; ok {
// tags = strings.Split(tstr, ",")
// }
// sts := &tailscaleSTSConfig{
// ParentResourceName: svc.Name,
// ParentResourceUID: string(svc.UID),
// Hostname: nameForService(svc),
// Tags: tags,
// ChildResourceLabels: crl,
// ProxyClassName: proxyClass,
// }
// a.mu.Lock()
// if a.shouldExposeClusterIP(svc) {
// sts.ClusterTargetIP = svc.Spec.ClusterIP
// a.managedIngressProxies.Add(svc.UID)
// gaugeIngressProxies.Set(int64(a.managedIngressProxies.Len()))
// } else if a.shouldExposeDNSName(svc) {
// sts.ClusterTargetDNSName = svc.Spec.ExternalName
// a.managedIngressProxies.Add(svc.UID)
// gaugeIngressProxies.Set(int64(a.managedIngressProxies.Len()))
// } else if ip := tailnetTargetAnnotation(svc); ip != "" {
// sts.TailnetTargetIP = ip
// a.managedEgressProxies.Add(svc.UID)
// gaugeEgressProxies.Set(int64(a.managedEgressProxies.Len()))
// } else if fqdn := svc.Annotations[AnnotationTailnetTargetFQDN]; fqdn != "" {
// fqdn := svc.Annotations[AnnotationTailnetTargetFQDN]
// if !strings.HasSuffix(fqdn, ".") {
// fqdn = fqdn + "."
// }
// sts.TailnetTargetFQDN = fqdn
// a.managedEgressProxies.Add(svc.UID)
// gaugeEgressProxies.Set(int64(a.managedEgressProxies.Len()))
// }
// a.mu.Unlock()
// var hsvc *corev1.Service
// if hsvc, err = a.ssr.Provision(ctx, logger, sts); err != nil {
// errMsg := fmt.Errorf("failed to provision: %w", err)
// tsoperator.SetServiceCondition(svc, tsapi.ProxyReady, metav1.ConditionFalse, reasonProxyFailed, errMsg.Error(), a.clock, logger)
// return errMsg
// }
// if sts.TailnetTargetIP != "" || sts.TailnetTargetFQDN != "" { // if an egress proxy
// clusterDomain := retrieveClusterDomain(a.tsNamespace, logger)
// headlessSvcName := hsvc.Name + "." + hsvc.Namespace + ".svc." + clusterDomain
// if svc.Spec.ExternalName != headlessSvcName || svc.Spec.Type != corev1.ServiceTypeExternalName {
// svc.Spec.ExternalName = headlessSvcName
// svc.Spec.Selector = nil
// svc.Spec.Type = corev1.ServiceTypeExternalName
// if err := a.Update(ctx, svc); err != nil {
// errMsg := fmt.Errorf("failed to update service: %w", err)
// tsoperator.SetServiceCondition(svc, tsapi.ProxyReady, metav1.ConditionFalse, reasonProxyFailed, errMsg.Error(), a.clock, logger)
// return errMsg
// }
// }
// tsoperator.SetServiceCondition(svc, tsapi.ProxyReady, metav1.ConditionTrue, reasonProxyCreated, reasonProxyCreated, a.clock, logger)
// return nil
// }
// if !isTailscaleLoadBalancerService(svc, a.isDefaultLoadBalancer) {
// logger.Debugf("service is not a LoadBalancer, so not updating ingress")
// tsoperator.SetServiceCondition(svc, tsapi.ProxyReady, metav1.ConditionTrue, reasonProxyCreated, reasonProxyCreated, a.clock, logger)
// return nil
// }
// _, tsHost, tsIPs, err := a.ssr.DeviceInfo(ctx, crl)
// if err != nil {
// return fmt.Errorf("failed to get device ID: %w", err)
// }
// if tsHost == "" {
// msg := "no Tailscale hostname known yet, waiting for proxy pod to finish auth"
// logger.Debug(msg)
// // No hostname yet. Wait for the proxy pod to auth.
// svc.Status.LoadBalancer.Ingress = nil
// tsoperator.SetServiceCondition(svc, tsapi.ProxyReady, metav1.ConditionFalse, reasonProxyPending, msg, a.clock, logger)
// return nil
// }
// logger.Debugf("setting Service LoadBalancer status to %q, %s", tsHost, strings.Join(tsIPs, ", "))
// ingress := []corev1.LoadBalancerIngress{
// {Hostname: tsHost},
// }
// clusterIPAddr, err := netip.ParseAddr(svc.Spec.ClusterIP)
// if err != nil {
// msg := fmt.Sprintf("failed to parse cluster IP: %v", err)
// tsoperator.SetServiceCondition(svc, tsapi.ProxyReady, metav1.ConditionFalse, reasonProxyFailed, msg, a.clock, logger)
// return errors.New(msg)
// }
// for _, ip := range tsIPs {
// addr, err := netip.ParseAddr(ip)
// if err != nil {
// continue
// }
// if addr.Is4() == clusterIPAddr.Is4() { // only add addresses of the same family
// ingress = append(ingress, corev1.LoadBalancerIngress{IP: ip})
// }
// }
// svc.Status.LoadBalancer.Ingress = ingress
// tsoperator.SetServiceCondition(svc, tsapi.ProxyReady, metav1.ConditionTrue, reasonProxyCreated, reasonProxyCreated, a.clock, logger)
2023-08-23 11:35:12 -04:00
return nil
}
2023-11-24 16:24:48 +00:00
func validateService ( svc * corev1 . Service ) [ ] string {
violations := make ( [ ] string , 0 )
if svc . Annotations [ AnnotationTailnetTargetFQDN ] != "" && svc . Annotations [ AnnotationTailnetTargetIP ] != "" {
2024-06-12 16:15:03 +01:00
violations = append ( violations , fmt . Sprintf ( "only one of annotations %s and %s can be set" , AnnotationTailnetTargetIP , AnnotationTailnetTargetFQDN ) )
2023-11-24 16:24:48 +00:00
}
if fqdn := svc . Annotations [ AnnotationTailnetTargetFQDN ] ; fqdn != "" {
if ! isMagicDNSName ( fqdn ) {
violations = append ( violations , fmt . Sprintf ( "invalid value of annotation %s: %q does not appear to be a valid MagicDNS name" , AnnotationTailnetTargetFQDN , fqdn ) )
}
}
2024-06-18 19:01:40 +01:00
svcName := nameForService ( svc )
if err := dnsname . ValidLabel ( svcName ) ; err != nil {
if _ , ok := svc . Annotations [ AnnotationHostname ] ; ok {
violations = append ( violations , fmt . Sprintf ( "invalid Tailscale hostname specified %q: %s" , svcName , err ) )
} else {
violations = append ( violations , fmt . Sprintf ( "invalid Tailscale hostname %q, use %q annotation to override: %s" , svcName , AnnotationHostname , err ) )
}
}
2023-11-24 16:24:48 +00:00
return violations
}
2023-08-23 11:35:12 -04:00
func ( a * ServiceReconciler ) shouldExpose ( svc * corev1 . Service ) bool {
2024-04-23 17:30:00 +01:00
return a . shouldExposeClusterIP ( svc ) || a . shouldExposeDNSName ( svc )
}
2024-05-02 17:29:46 +01:00
func ( a * ServiceReconciler ) shouldExposeDNSName ( svc * corev1 . Service ) bool {
return hasExposeAnnotation ( svc ) && svc . Spec . Type == corev1 . ServiceTypeExternalName && svc . Spec . ExternalName != ""
}
2024-04-23 17:30:00 +01:00
func ( a * ServiceReconciler ) shouldExposeClusterIP ( svc * corev1 . Service ) bool {
2023-08-23 11:35:12 -04:00
if svc . Spec . ClusterIP == "" || svc . Spec . ClusterIP == "None" {
return false
}
2024-05-02 17:29:46 +01:00
return isTailscaleLoadBalancerService ( svc , a . isDefaultLoadBalancer ) || hasExposeAnnotation ( svc )
2024-04-23 17:30:00 +01:00
}
2024-05-02 17:29:46 +01:00
func isTailscaleLoadBalancerService ( svc * corev1 . Service , isDefaultLoadBalancer bool ) bool {
2023-08-23 11:35:12 -04:00
return svc != nil &&
svc . Spec . Type == corev1 . ServiceTypeLoadBalancer &&
2023-08-17 02:35:36 +02:00
( svc . Spec . LoadBalancerClass != nil && * svc . Spec . LoadBalancerClass == "tailscale" ||
2024-05-02 17:29:46 +01:00
svc . Spec . LoadBalancerClass == nil && isDefaultLoadBalancer )
2023-08-23 11:35:12 -04:00
}
2023-08-30 08:31:37 +01:00
// hasExposeAnnotation reports whether Service has the tailscale.com/expose
// annotation set
2024-05-02 17:29:46 +01:00
func hasExposeAnnotation ( svc * corev1 . Service ) bool {
2023-08-30 08:31:37 +01:00
return svc != nil && svc . Annotations [ AnnotationExpose ] == "true"
}
2024-06-18 19:01:40 +01:00
// tailnetTargetAnnotation returns the value of tailscale.com/tailnet-ip
2023-09-20 08:51:50 -07:00
// annotation or of the deprecated tailscale.com/ts-tailnet-target-ip
// annotation. If neither is set, it returns an empty string. If both are set,
// it returns the value of the new annotation.
2024-05-02 17:29:46 +01:00
func tailnetTargetAnnotation ( svc * corev1 . Service ) string {
2023-09-20 08:51:50 -07:00
if svc == nil {
return ""
}
if ip := svc . Annotations [ AnnotationTailnetTargetIP ] ; ip != "" {
return ip
}
return svc . Annotations [ annotationTailnetTargetIPOld ]
2023-08-23 11:35:12 -04:00
}
2024-02-13 05:27:54 +00:00
2024-08-20 10:50:40 -04:00
// proxyClassForObject returns the proxy class for the given object. If the
// object does not have a proxy class label, it returns the default proxy class
func proxyClassForObject ( o client . Object , proxyDefaultClass string ) string {
proxyClass , exists := o . GetLabels ( ) [ LabelProxyClass ]
if ! exists {
proxyClass = proxyDefaultClass
}
return proxyClass
2024-02-13 05:27:54 +00:00
}
func proxyClassIsReady ( ctx context . Context , name string , cl client . Client ) ( bool , error ) {
proxyClass := new ( tsapi . ProxyClass )
if err := cl . Get ( ctx , types . NamespacedName { Name : name } , proxyClass ) ; err != nil {
return false , fmt . Errorf ( "error getting ProxyClass %s: %w" , name , err )
}
return tsoperator . ProxyClassIsReady ( proxyClass ) , nil
}
2024-04-19 16:49:46 +01:00
// retrieveClusterDomain determines and retrieves cluster domain i.e
// (cluster.local) in which this Pod is running by parsing search domains in
// /etc/resolv.conf. If an error is encountered at any point during the process,
// defaults cluster domain to 'cluster.local'.
func retrieveClusterDomain ( namespace string , logger * zap . SugaredLogger ) string {
logger . Infof ( "attempting to retrieve cluster domain.." )
conf , err := resolvconffile . ParseFile ( resolvConfPath )
if err != nil {
// Vast majority of clusters use the cluster.local domain, so it
// is probably better to fall back to that than error out.
logger . Infof ( "[unexpected] error parsing /etc/resolv.conf to determine cluster domain, defaulting to 'cluster.local'." )
return defaultClusterDomain
}
return clusterDomainFromResolverConf ( conf , namespace , logger )
}
// clusterDomainFromResolverConf attempts to retrieve cluster domain from the provided resolver config.
// It expects the first three search domains in the resolver config to be be ['<namespace>.svc.<cluster-domain>, svc.<cluster-domain>, <cluster-domain>, ...]
// If the first three domains match the expected structure, it returns the third.
// If the domains don't match the expected structure or an error is encountered, it defaults to 'cluster.local' domain.
func clusterDomainFromResolverConf ( conf * resolvconffile . Config , namespace string , logger * zap . SugaredLogger ) string {
if len ( conf . SearchDomains ) < 3 {
logger . Infof ( "[unexpected] resolver config contains only %d search domains, at least three expected.\nDefaulting cluster domain to 'cluster.local'." )
return defaultClusterDomain
}
first := conf . SearchDomains [ 0 ]
if ! strings . HasPrefix ( string ( first ) , namespace + ".svc" ) {
logger . Infof ( "[unexpected] first search domain in resolver config is %s; expected %s.\nDefaulting cluster domain to 'cluster.local'." , first , namespace + ".svc.<cluster-domain>" )
return defaultClusterDomain
}
second := conf . SearchDomains [ 1 ]
if ! strings . HasPrefix ( string ( second ) , "svc" ) {
logger . Infof ( "[unexpected] second search domain in resolver config is %s; expected 'svc.<cluster-domain>'.\nDefaulting cluster domain to 'cluster.local'." , second )
return defaultClusterDomain
}
// Trim the trailing dot for backwards compatibility purposes as the
// cluster domain was previously hardcoded to 'cluster.local' without a
// trailing dot.
probablyClusterDomain := strings . TrimPrefix ( second . WithoutTrailingDot ( ) , "svc." )
third := conf . SearchDomains [ 2 ]
if ! strings . EqualFold ( third . WithoutTrailingDot ( ) , probablyClusterDomain ) {
logger . Infof ( "[unexpected] expected resolver config to contain serch domains <namespace>.svc.<cluster-domain>, svc.<cluster-domain>, <cluster-domain>; got %s %s %s\n. Defaulting cluster domain to 'cluster.local'." , first , second , third )
return defaultClusterDomain
}
logger . Infof ( "Cluster domain %q extracted from resolver config" , probablyClusterDomain )
return probablyClusterDomain
}