ingress-nginx-helm/controllers/nginx/controller.go

911 lines
26 KiB
Go
Raw Normal View History

2016-02-22 00:13:08 +00:00
/*
Copyright 2015 The Kubernetes Authors All rights reserved.
Licensed under the Apache License, Version 2.0 (the "License");
you may not use this file except in compliance with the License.
You may obtain a copy of the License at
http://www.apache.org/licenses/LICENSE-2.0
Unless required by applicable law or agreed to in writing, software
distributed under the License is distributed on an "AS IS" BASIS,
WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
See the License for the specific language governing permissions and
limitations under the License.
*/
package main
import (
2016-04-14 23:42:37 +00:00
"encoding/json"
2016-02-22 00:13:08 +00:00
"fmt"
"reflect"
"sort"
2016-03-19 23:29:29 +00:00
"strconv"
"strings"
2016-02-22 00:13:08 +00:00
"sync"
"time"
"github.com/golang/glog"
"k8s.io/kubernetes/pkg/api"
2016-04-14 23:42:37 +00:00
podutil "k8s.io/kubernetes/pkg/api/pod"
2016-02-22 00:13:08 +00:00
"k8s.io/kubernetes/pkg/apis/extensions"
"k8s.io/kubernetes/pkg/client/cache"
"k8s.io/kubernetes/pkg/client/record"
2016-02-22 00:13:08 +00:00
client "k8s.io/kubernetes/pkg/client/unversioned"
"k8s.io/kubernetes/pkg/controller/framework"
2016-04-14 23:42:37 +00:00
"k8s.io/kubernetes/pkg/labels"
2016-02-22 00:13:08 +00:00
"k8s.io/kubernetes/pkg/runtime"
"k8s.io/kubernetes/pkg/util/intstr"
2016-02-22 00:13:08 +00:00
"k8s.io/kubernetes/pkg/watch"
2016-03-28 01:12:15 +00:00
"k8s.io/contrib/ingress/controllers/nginx/nginx"
2016-02-22 00:13:08 +00:00
)
const (
2016-04-14 23:42:37 +00:00
defUpstreamName = "upstream-default-backend"
defServerName = "_"
namedPortAnnotation = "kubernetes.io/ingress-named-ports"
2016-02-22 00:13:08 +00:00
)
var (
keyFunc = framework.DeletionHandlingMetaNamespaceKeyFunc
)
2016-04-14 23:42:37 +00:00
type namedPortMapping map[string]string
func (npm namedPortMapping) getPort(name string) (string, bool) {
val, ok := npm.getMappings()[name]
return val, ok
}
func (npm namedPortMapping) getMappings() map[string]string {
data := npm[namedPortAnnotation]
var mapping map[string]string
if data == "" {
return mapping
}
if err := json.Unmarshal([]byte(data), &mapping); err != nil {
glog.Errorf("unexpected error reading annotations: %v", err)
}
return mapping
}
2016-02-22 00:13:08 +00:00
// loadBalancerController watches the kubernetes api and adds/removes services
// from the loadbalancer
type loadBalancerController struct {
2016-03-19 23:29:29 +00:00
client *client.Client
ingController *framework.Controller
endpController *framework.Controller
svcController *framework.Controller
ingLister StoreToIngressLister
svcLister cache.StoreToServiceLister
endpLister cache.StoreToEndpointsLister
nginx *nginx.Manager
2016-04-06 14:46:06 +00:00
podInfo *podInfo
2016-03-19 23:29:29 +00:00
defaultSvc string
nxgConfigMap string
tcpConfigMap string
udpConfigMap string
recorder record.EventRecorder
syncQueue *taskQueue
// taskQueue used to update the status of the Ingress rules.
// this avoids a sync execution in the ResourceEventHandlerFuncs
ingQueue *taskQueue
2016-04-14 23:42:37 +00:00
// used to update the annotation that matches a service using one or
// more named ports to an endpoint port
svcEpQueue *taskQueue
2016-02-22 00:13:08 +00:00
// stopLock is used to enforce only a single call to Stop is active.
// Needed because we allow stopping through an http endpoint and
// allowing concurrent stoppers leads to stack traces.
stopLock sync.Mutex
shutdown bool
2016-03-19 23:29:29 +00:00
stopCh chan struct{}
2016-02-22 00:13:08 +00:00
}
// newLoadBalancerController creates a controller for nginx loadbalancer
2016-03-19 23:29:29 +00:00
func newLoadBalancerController(kubeClient *client.Client, resyncPeriod time.Duration, defaultSvc,
2016-04-06 14:46:06 +00:00
namespace, nxgConfigMapName, tcpConfigMapName, udpConfigMapName string, runtimeInfo *podInfo) (*loadBalancerController, error) {
eventBroadcaster := record.NewBroadcaster()
eventBroadcaster.StartLogging(glog.Infof)
eventBroadcaster.StartRecordingToSink(kubeClient.Events(namespace))
2016-02-22 00:13:08 +00:00
lbc := loadBalancerController{
client: kubeClient,
stopCh: make(chan struct{}),
2016-04-06 14:46:06 +00:00
podInfo: runtimeInfo,
2016-03-19 23:29:29 +00:00
nginx: nginx.NewManager(kubeClient),
nxgConfigMap: nxgConfigMapName,
tcpConfigMap: tcpConfigMapName,
udpConfigMap: udpConfigMapName,
2016-03-19 23:29:29 +00:00
defaultSvc: defaultSvc,
recorder: eventBroadcaster.NewRecorder(api.EventSource{Component: "loadbalancer-controller"}),
2016-02-22 00:13:08 +00:00
}
lbc.syncQueue = NewTaskQueue(lbc.sync)
lbc.ingQueue = NewTaskQueue(lbc.updateIngressStatus)
2016-04-14 23:42:37 +00:00
lbc.svcEpQueue = NewTaskQueue(lbc.updateEpNamedPorts)
ingEventHandler := framework.ResourceEventHandlerFuncs{
AddFunc: func(obj interface{}) {
addIng := obj.(*extensions.Ingress)
lbc.recorder.Eventf(addIng, api.EventTypeNormal, "CREATE", fmt.Sprintf("%s/%s", addIng.Namespace, addIng.Name))
2016-03-31 17:59:28 +00:00
lbc.ingQueue.enqueue(obj)
lbc.svcEpQueue.enqueue(obj)
lbc.syncQueue.enqueue(obj)
},
DeleteFunc: func(obj interface{}) {
upIng := obj.(*extensions.Ingress)
lbc.recorder.Eventf(upIng, api.EventTypeNormal, "DELETE", fmt.Sprintf("%s/%s", upIng.Namespace, upIng.Name))
lbc.syncQueue.enqueue(obj)
},
UpdateFunc: func(old, cur interface{}) {
if !reflect.DeepEqual(old, cur) {
upIng := cur.(*extensions.Ingress)
lbc.recorder.Eventf(upIng, api.EventTypeNormal, "UPDATE", fmt.Sprintf("%s/%s", upIng.Namespace, upIng.Name))
2016-03-31 17:59:28 +00:00
lbc.ingQueue.enqueue(cur)
lbc.svcEpQueue.enqueue(cur)
lbc.syncQueue.enqueue(cur)
}
},
}
eventHandler := framework.ResourceEventHandlerFuncs{
AddFunc: func(obj interface{}) {
lbc.syncQueue.enqueue(obj)
},
DeleteFunc: func(obj interface{}) {
lbc.syncQueue.enqueue(obj)
},
UpdateFunc: func(old, cur interface{}) {
if !reflect.DeepEqual(old, cur) {
lbc.syncQueue.enqueue(cur)
}
},
}
2016-02-22 00:13:08 +00:00
lbc.ingLister.Store, lbc.ingController = framework.NewInformer(
&cache.ListWatch{
ListFunc: ingressListFunc(lbc.client, namespace),
WatchFunc: ingressWatchFunc(lbc.client, namespace),
},
&extensions.Ingress{}, resyncPeriod, ingEventHandler)
2016-02-22 00:13:08 +00:00
lbc.endpLister.Store, lbc.endpController = framework.NewInformer(
&cache.ListWatch{
2016-03-19 23:29:29 +00:00
ListFunc: endpointsListFunc(lbc.client, namespace),
WatchFunc: endpointsWatchFunc(lbc.client, namespace),
2016-02-22 00:13:08 +00:00
},
&api.Endpoints{}, resyncPeriod, eventHandler)
2016-02-22 00:13:08 +00:00
lbc.svcLister.Store, lbc.svcController = framework.NewInformer(
2016-02-22 00:13:08 +00:00
&cache.ListWatch{
2016-03-19 23:29:29 +00:00
ListFunc: serviceListFunc(lbc.client, namespace),
WatchFunc: serviceWatchFunc(lbc.client, namespace),
2016-02-22 00:13:08 +00:00
},
&api.Service{}, resyncPeriod, framework.ResourceEventHandlerFuncs{})
2016-02-22 00:13:08 +00:00
return &lbc, nil
}
func ingressListFunc(c *client.Client, ns string) func(api.ListOptions) (runtime.Object, error) {
return func(opts api.ListOptions) (runtime.Object, error) {
return c.Extensions().Ingress(ns).List(opts)
}
}
func ingressWatchFunc(c *client.Client, ns string) func(options api.ListOptions) (watch.Interface, error) {
return func(options api.ListOptions) (watch.Interface, error) {
return c.Extensions().Ingress(ns).Watch(options)
}
}
func serviceListFunc(c *client.Client, ns string) func(api.ListOptions) (runtime.Object, error) {
return func(opts api.ListOptions) (runtime.Object, error) {
return c.Services(ns).List(opts)
2016-02-22 00:13:08 +00:00
}
}
func serviceWatchFunc(c *client.Client, ns string) func(options api.ListOptions) (watch.Interface, error) {
return func(options api.ListOptions) (watch.Interface, error) {
return c.Services(ns).Watch(options)
2016-02-22 00:13:08 +00:00
}
}
2016-02-22 00:13:08 +00:00
func endpointsListFunc(c *client.Client, ns string) func(api.ListOptions) (runtime.Object, error) {
return func(opts api.ListOptions) (runtime.Object, error) {
return c.Endpoints(ns).List(opts)
2016-02-22 00:13:08 +00:00
}
}
func endpointsWatchFunc(c *client.Client, ns string) func(options api.ListOptions) (watch.Interface, error) {
return func(options api.ListOptions) (watch.Interface, error) {
return c.Endpoints(ns).Watch(options)
2016-02-22 00:13:08 +00:00
}
}
func (lbc *loadBalancerController) controllersInSync() bool {
return lbc.ingController.HasSynced() && lbc.svcController.HasSynced() && lbc.endpController.HasSynced()
}
2016-03-19 23:29:29 +00:00
func (lbc *loadBalancerController) getConfigMap(ns, name string) (*api.ConfigMap, error) {
return lbc.client.ConfigMaps(ns).Get(name)
}
2016-03-19 23:29:29 +00:00
func (lbc *loadBalancerController) getTCPConfigMap(ns, name string) (*api.ConfigMap, error) {
return lbc.client.ConfigMaps(ns).Get(name)
}
func (lbc *loadBalancerController) getUDPConfigMap(ns, name string) (*api.ConfigMap, error) {
return lbc.client.ConfigMaps(ns).Get(name)
}
2016-04-14 23:42:37 +00:00
func (lbc *loadBalancerController) updateEpNamedPorts(key string) {
if !lbc.controllersInSync() {
lbc.svcEpQueue.requeue(key, fmt.Errorf("deferring sync till endpoints controller has synced"))
return
}
glog.V(4).Infof("checking if service %v uses named ports to update annotation %v", key, namedPortAnnotation)
ingObj, ingExists, err := lbc.ingLister.Store.GetByKey(key)
2016-04-14 23:42:37 +00:00
if err != nil {
glog.Warningf("error getting service %v: %v", key, err)
return
}
if !ingExists {
2016-04-14 23:42:37 +00:00
glog.Warningf("service %v not found", key)
return
}
ing := ingObj.(*extensions.Ingress)
for _, rule := range ing.Spec.Rules {
if rule.IngressRuleValue.HTTP == nil {
continue
}
for _, path := range rule.HTTP.Paths {
svcKey := fmt.Sprintf("%v/%v", ing.GetNamespace(), path.Backend.ServiceName)
svcObj, svcExists, err := lbc.svcLister.Store.GetByKey(svcKey)
if err != nil {
glog.Infof("error getting service %v from the cache: %v", svcKey, err)
continue
}
if !svcExists {
glog.Warningf("service %v does no exists", svcKey)
continue
}
svc := svcObj.(*api.Service)
if svc.Spec.Selector == nil {
return
}
lbc.checkSvcForUpdate(svc)
}
2016-04-14 23:42:37 +00:00
}
}
2016-04-14 23:42:37 +00:00
func (lbc *loadBalancerController) checkSvcForUpdate(svc *api.Service) {
2016-04-14 23:42:37 +00:00
pods, err := lbc.client.Pods(svc.Namespace).List(api.ListOptions{
LabelSelector: labels.Set(svc.Spec.Selector).AsSelector(),
})
if err != nil {
glog.Errorf("error searching service pods %v/%v: %v", svc.Namespace, svc.Name, err)
2016-04-14 23:42:37 +00:00
return
}
namedPorts := map[string]string{}
for i := range pods.Items {
pod := &pods.Items[i]
glog.V(4).Infof("checking pod %v/%v for named port information", pod.Namespace, pod.Name)
2016-04-14 23:42:37 +00:00
for i := range svc.Spec.Ports {
servicePort := &svc.Spec.Ports[i]
_, err := strconv.Atoi(servicePort.TargetPort.StrVal)
if err != nil {
portNum, err := podutil.FindPort(pod, servicePort)
if err != nil {
glog.V(4).Infof("failed to find port for service %s/%s: %v", svc.Namespace, svc.Name, err)
2016-04-14 23:42:37 +00:00
continue
}
if servicePort.TargetPort.StrVal == "" {
continue
}
namedPorts[servicePort.TargetPort.StrVal] = fmt.Sprintf("%v", portNum)
}
}
}
if svc.ObjectMeta.Annotations == nil {
svc.ObjectMeta.Annotations = map[string]string{}
}
curNamedPort := svc.ObjectMeta.Annotations[namedPortAnnotation]
if !reflect.DeepEqual(curNamedPort, namedPorts) {
2016-04-14 23:42:37 +00:00
data, _ := json.Marshal(namedPorts)
svc.ObjectMeta.Annotations[namedPortAnnotation] = string(data)
glog.Infof("updating service %v with new named port mappings", svc.Name)
_, err := lbc.client.Services(svc.Namespace).Update(svc)
if err != nil {
glog.Errorf("error syncing service %v/%v: %v", svc.Namespace, svc.Name, err)
2016-04-14 23:42:37 +00:00
}
}
}
func (lbc *loadBalancerController) sync(key string) {
if !lbc.controllersInSync() {
lbc.syncQueue.requeue(key, fmt.Errorf("deferring sync till endpoints controller has synced"))
return
}
ings := lbc.ingLister.Store.List()
upstreams, servers := lbc.getUpstreamServers(ings)
2016-03-19 23:29:29 +00:00
var cfg *api.ConfigMap
ns, name, _ := parseNsName(lbc.nxgConfigMap)
cfg, err := lbc.getConfigMap(ns, name)
if err != nil {
cfg = &api.ConfigMap{}
}
ngxConfig := lbc.nginx.ReadConfig(cfg)
2016-03-19 23:29:29 +00:00
lbc.nginx.CheckAndReload(ngxConfig, nginx.IngressConfig{
Upstreams: upstreams,
Servers: servers,
TCPUpstreams: lbc.getTCPServices(),
UDPUpstreams: lbc.getUDPServices(),
2016-03-19 23:29:29 +00:00
})
}
func (lbc *loadBalancerController) updateIngressStatus(key string) {
2016-03-31 17:59:28 +00:00
if !lbc.controllersInSync() {
lbc.ingQueue.requeue(key, fmt.Errorf("deferring sync till endpoints controller has synced"))
return
}
obj, ingExists, err := lbc.ingLister.Store.GetByKey(key)
if err != nil {
2016-03-31 17:59:28 +00:00
lbc.ingQueue.requeue(key, err)
return
}
if !ingExists {
return
}
2016-03-31 17:59:28 +00:00
ing := obj.(*extensions.Ingress)
2016-03-31 17:59:28 +00:00
ingClient := lbc.client.Extensions().Ingress(ing.Namespace)
currIng, err := ingClient.Get(ing.Name)
if err != nil {
glog.Errorf("unexpected error searching Ingress %v/%v: %v", ing.Namespace, ing.Name, err)
return
}
2016-03-31 17:59:28 +00:00
lbIPs := ing.Status.LoadBalancer.Ingress
if !lbc.isStatusIPDefined(lbIPs) {
2016-04-06 14:46:06 +00:00
glog.Infof("Updating loadbalancer %v/%v with IP %v", ing.Namespace, ing.Name, lbc.podInfo.NodeIP)
currIng.Status.LoadBalancer.Ingress = append(currIng.Status.LoadBalancer.Ingress, api.LoadBalancerIngress{
2016-04-06 14:46:06 +00:00
IP: lbc.podInfo.NodeIP,
})
if _, err := ingClient.UpdateStatus(currIng); err != nil {
lbc.recorder.Eventf(currIng, api.EventTypeWarning, "UPDATE", "error: %v", err)
return
2016-03-31 17:59:28 +00:00
}
2016-04-06 14:46:06 +00:00
lbc.recorder.Eventf(currIng, api.EventTypeNormal, "CREATE", "ip: %v", lbc.podInfo.NodeIP)
}
}
func (lbc *loadBalancerController) isStatusIPDefined(lbings []api.LoadBalancerIngress) bool {
for _, lbing := range lbings {
2016-04-06 14:46:06 +00:00
if lbing.IP == lbc.podInfo.NodeIP {
return true
}
}
return false
}
2016-03-19 23:29:29 +00:00
func (lbc *loadBalancerController) getTCPServices() []*nginx.Location {
if lbc.tcpConfigMap == "" {
// no configmap for TCP services
return []*nginx.Location{}
}
ns, name, err := parseNsName(lbc.tcpConfigMap)
if err != nil {
glog.Warningf("%v", err)
return []*nginx.Location{}
}
tcpMap, err := lbc.getTCPConfigMap(ns, name)
if err != nil {
glog.V(3).Infof("no configured tcp services found: %v", err)
return []*nginx.Location{}
}
return lbc.getServices(tcpMap.Data, api.ProtocolTCP)
}
func (lbc *loadBalancerController) getUDPServices() []*nginx.Location {
if lbc.udpConfigMap == "" {
// no configmap for TCP services
return []*nginx.Location{}
}
ns, name, err := parseNsName(lbc.udpConfigMap)
if err != nil {
glog.Warningf("%v", err)
return []*nginx.Location{}
}
tcpMap, err := lbc.getUDPConfigMap(ns, name)
if err != nil {
glog.V(3).Infof("no configured tcp services found: %v", err)
return []*nginx.Location{}
}
return lbc.getServices(tcpMap.Data, api.ProtocolUDP)
}
func (lbc *loadBalancerController) getServices(data map[string]string, proto api.Protocol) []*nginx.Location {
var svcs []*nginx.Location
2016-03-19 23:29:29 +00:00
// k -> port to expose in nginx
// v -> <namespace>/<service name>:<port from service to be used>
for k, v := range data {
2016-03-19 23:29:29 +00:00
port, err := strconv.Atoi(k)
if err != nil {
glog.Warningf("%v is not valid as a TCP port", k)
continue
}
svcPort := strings.Split(v, ":")
if len(svcPort) != 2 {
glog.Warningf("invalid format (namespace/name:port) '%v'", k)
continue
}
svcNs, svcName, err := parseNsName(svcPort[0])
if err != nil {
glog.Warningf("%v", err)
continue
}
svcObj, svcExists, err := lbc.svcLister.Store.GetByKey(svcPort[0])
if err != nil {
glog.Warningf("error getting service %v: %v", svcPort[0], err)
continue
}
if !svcExists {
glog.Warningf("service %v was not found", svcPort[0])
continue
}
svc := svcObj.(*api.Service)
var endps []nginx.UpstreamServer
targetPort, err := strconv.Atoi(svcPort[1])
if err != nil {
2016-04-14 23:42:37 +00:00
for _, sp := range svc.Spec.Ports {
if sp.Name == svcPort[1] {
endps = lbc.getEndpoints(svc, sp.TargetPort, proto)
break
}
}
2016-03-19 23:29:29 +00:00
} else {
// we need to use the TargetPort (where the endpoints are running)
for _, sp := range svc.Spec.Ports {
if sp.Port == targetPort {
endps = lbc.getEndpoints(svc, sp.TargetPort, proto)
2016-03-19 23:29:29 +00:00
break
}
}
}
// tcp upstreams cannot contain empty upstreams and there is no
// default backend equivalent for TCP
if len(endps) == 0 {
glog.Warningf("service %v/%v does no have any active endpoints", svcNs, svcName)
continue
}
svcs = append(svcs, &nginx.Location{
2016-03-19 23:29:29 +00:00
Path: k,
Upstream: nginx.Upstream{
Name: fmt.Sprintf("%v-%v-%v", svcNs, svcName, port),
Backends: endps,
},
})
}
return svcs
2016-03-19 23:29:29 +00:00
}
func (lbc *loadBalancerController) getDefaultUpstream() *nginx.Upstream {
upstream := &nginx.Upstream{
Name: defUpstreamName,
}
svcKey := lbc.defaultSvc
svcObj, svcExists, err := lbc.svcLister.Store.GetByKey(svcKey)
if err != nil {
glog.Warningf("unexpected error searching the default backend %v: %v", lbc.defaultSvc, err)
upstream.Backends = append(upstream.Backends, nginx.NewDefaultServer())
return upstream
}
if !svcExists {
glog.Warningf("service %v does no exists", svcKey)
upstream.Backends = append(upstream.Backends, nginx.NewDefaultServer())
return upstream
}
svc := svcObj.(*api.Service)
endps := lbc.getEndpoints(svc, svc.Spec.Ports[0].TargetPort, api.ProtocolTCP)
2016-03-19 23:29:29 +00:00
if len(endps) == 0 {
glog.Warningf("service %v does no have any active endpoints", svcKey)
upstream.Backends = append(upstream.Backends, nginx.NewDefaultServer())
} else {
upstream.Backends = append(upstream.Backends, endps...)
}
return upstream
}
2016-03-16 18:57:36 +00:00
func (lbc *loadBalancerController) getUpstreamServers(data []interface{}) ([]*nginx.Upstream, []*nginx.Server) {
upstreams := lbc.createUpstreams(data)
2016-03-19 23:29:29 +00:00
upstreams[defUpstreamName] = lbc.getDefaultUpstream()
2016-04-02 20:41:41 +00:00
servers := lbc.createServers(data)
// default server - no servername.
servers[defServerName] = &nginx.Server{
Name: defServerName,
2016-04-06 14:46:06 +00:00
Locations: []*nginx.Location{{
2016-04-02 20:41:41 +00:00
Path: "/",
Upstream: *lbc.getDefaultUpstream(),
},
},
}
for _, ingIf := range data {
ing := ingIf.(*extensions.Ingress)
for _, rule := range ing.Spec.Rules {
if rule.IngressRuleValue.HTTP == nil {
continue
}
2016-03-16 18:57:36 +00:00
server := servers[rule.Host]
2016-03-16 18:57:36 +00:00
for _, path := range rule.HTTP.Paths {
2016-04-14 23:42:37 +00:00
upsName := fmt.Sprintf("%v-%v-%v", ing.GetNamespace(), path.Backend.ServiceName, path.Backend.ServicePort.StrVal)
2016-03-16 18:57:36 +00:00
ups := upstreams[upsName]
2016-03-19 23:29:29 +00:00
svcKey := fmt.Sprintf("%v/%v", ing.GetNamespace(), path.Backend.ServiceName)
svcObj, svcExists, err := lbc.svcLister.Store.GetByKey(svcKey)
if err != nil {
glog.Infof("error getting service %v from the cache: %v", svcKey, err)
continue
}
if !svcExists {
glog.Warningf("service %v does no exists", svcKey)
continue
}
svc := svcObj.(*api.Service)
for _, servicePort := range svc.Spec.Ports {
2016-04-14 23:42:37 +00:00
port := servicePort.TargetPort
if servicePort.Name != "" {
port = intstr.FromString(servicePort.Name)
}
if port == path.Backend.ServicePort {
endps := lbc.getEndpoints(svc, port, api.ProtocolTCP)
if len(endps) == 0 {
glog.Warningf("service %v does no have any active endpoints", svcKey)
}
ups.Backends = append(ups.Backends, endps...)
break
}
}
// Validate that there is no another previuous rule
// for the same host and path.
skipLoc := false
for _, loc := range server.Locations {
if loc.Path == path.Path {
lbc.recorder.Eventf(ing, api.EventTypeWarning, "MAPPING", "Path '%v' already defined in another Ingress rule", path)
skipLoc = true
2016-03-16 18:57:36 +00:00
break
}
}
if skipLoc == false {
server.Locations = append(server.Locations, &nginx.Location{
Path: path.Path,
Upstream: *ups,
})
}
2016-03-19 23:29:29 +00:00
}
}
}
2016-03-16 18:57:36 +00:00
// TODO: find a way to make this more readable
// The structs must be ordered to always generate the same file
// if the content does not change.
aUpstreams := make([]*nginx.Upstream, 0, len(upstreams))
for _, value := range upstreams {
if len(value.Backends) == 0 {
value.Backends = append(value.Backends, nginx.NewDefaultServer())
}
sort.Sort(nginx.UpstreamServerByAddrPort(value.Backends))
aUpstreams = append(aUpstreams, value)
}
sort.Sort(nginx.UpstreamByNameServers(aUpstreams))
2016-03-16 18:57:36 +00:00
aServers := make([]*nginx.Server, 0, len(servers))
for _, value := range servers {
sort.Sort(nginx.LocationByPath(value.Locations))
aServers = append(aServers, value)
}
sort.Sort(nginx.ServerByName(aServers))
return aUpstreams, aServers
}
2016-03-16 18:57:36 +00:00
func (lbc *loadBalancerController) createUpstreams(data []interface{}) map[string]*nginx.Upstream {
upstreams := make(map[string]*nginx.Upstream)
for _, ingIf := range data {
ing := ingIf.(*extensions.Ingress)
for _, rule := range ing.Spec.Rules {
if rule.IngressRuleValue.HTTP == nil {
continue
}
for _, path := range rule.HTTP.Paths {
2016-04-14 23:42:37 +00:00
name := fmt.Sprintf("%v-%v-%v", ing.GetNamespace(), path.Backend.ServiceName, path.Backend.ServicePort.StrVal)
2016-03-16 18:57:36 +00:00
if _, ok := upstreams[name]; !ok {
upstreams[name] = nginx.NewUpstream(name)
}
}
}
}
return upstreams
}
func (lbc *loadBalancerController) createServers(data []interface{}) map[string]*nginx.Server {
servers := make(map[string]*nginx.Server)
pems := lbc.getPemsFromIngress(data)
for _, ingIf := range data {
ing := ingIf.(*extensions.Ingress)
for _, rule := range ing.Spec.Rules {
if _, ok := servers[rule.Host]; !ok {
2016-03-19 23:29:29 +00:00
servers[rule.Host] = &nginx.Server{Name: rule.Host, Locations: []*nginx.Location{}}
2016-03-16 18:57:36 +00:00
}
if pemFile, ok := pems[rule.Host]; ok {
server := servers[rule.Host]
server.SSL = true
server.SSLCertificate = pemFile
server.SSLCertificateKey = pemFile
}
}
}
return servers
}
func (lbc *loadBalancerController) getPemsFromIngress(data []interface{}) map[string]string {
pems := make(map[string]string)
for _, ingIf := range data {
ing := ingIf.(*extensions.Ingress)
for _, tls := range ing.Spec.TLS {
secretName := tls.SecretName
secret, err := lbc.client.Secrets(ing.Namespace).Get(secretName)
if err != nil {
glog.Warningf("Error retriveing secret %v for ing %v: %v", secretName, ing.Name, err)
continue
}
cert, ok := secret.Data[api.TLSCertKey]
if !ok {
glog.Warningf("Secret %v has no private key", secretName)
continue
}
key, ok := secret.Data[api.TLSPrivateKeyKey]
if !ok {
glog.Warningf("Secret %v has no cert", secretName)
continue
}
pemFileName, err := lbc.nginx.AddOrUpdateCertAndKey(fmt.Sprintf("%v-%v", ing.Namespace, secretName), string(cert), string(key))
if err != nil {
glog.Errorf("No valid SSL certificate found in secret %v: %v", secretName, err)
continue
}
cn, err := lbc.nginx.CheckSSLCertificate(pemFileName)
2016-03-19 00:41:31 +00:00
if err != nil {
glog.Errorf("No valid SSL certificate found in secret %v: %v", secretName, err)
2016-03-19 00:41:31 +00:00
continue
}
2016-04-02 20:41:41 +00:00
if len(tls.Hosts) == 0 {
if _, ok := pems["_"]; ok {
glog.Warningf("It is not possible to use %v secret for default SSL certificate because there is one already defined", secretName)
continue
}
pems["_"] = pemFileName
glog.Infof("Using the secret %v as source for the default SSL certificate", secretName)
continue
}
for _, host := range tls.Hosts {
2016-03-19 00:41:31 +00:00
if isHostValid(host, cn) {
pems[host] = pemFileName
} else {
glog.Warningf("SSL Certificate stored in secret %v is not valid for the host %v defined in the Ingress rule %v", secretName, host, ing.Name)
}
}
}
}
return pems
}
// getEndpoints returns a list of <endpoint ip>:<port> for a given service/target port combination.
func (lbc *loadBalancerController) getEndpoints(s *api.Service, servicePort intstr.IntOrString, proto api.Protocol) []nginx.UpstreamServer {
2016-03-19 23:29:29 +00:00
glog.V(3).Infof("getting endpoints for service %v/%v and port %v", s.Namespace, s.Name, servicePort.String())
ep, err := lbc.endpLister.GetServiceEndpoints(s)
if err != nil {
glog.Warningf("unexpected error obtaining service endpoints: %v", err)
return []nginx.UpstreamServer{}
}
2016-03-19 23:29:29 +00:00
upsServers := []nginx.UpstreamServer{}
for _, ss := range ep.Subsets {
for _, epPort := range ss.Ports {
if !reflect.DeepEqual(epPort.Protocol, proto) {
continue
}
var targetPort int
switch servicePort.Type {
case intstr.Int:
if epPort.Port == servicePort.IntValue() {
targetPort = epPort.Port
}
case intstr.String:
2016-04-14 23:42:37 +00:00
if val, ok := namedPortMapping(s.ObjectMeta.Annotations).getPort(servicePort.StrVal); ok {
port, err := strconv.Atoi(val)
if err != nil {
glog.Warningf("%v is not valid as a port", val)
continue
}
if epPort.Protocol == proto {
targetPort = port
}
}
}
if targetPort == 0 {
continue
}
for _, epAddress := range ss.Addresses {
ups := nginx.UpstreamServer{Address: epAddress.IP, Port: fmt.Sprintf("%v", targetPort)}
upsServers = append(upsServers, ups)
}
}
}
2016-03-19 23:29:29 +00:00
glog.V(3).Infof("endpoints found: %v", upsServers)
return upsServers
}
2016-02-22 00:13:08 +00:00
// Stop stops the loadbalancer controller.
func (lbc *loadBalancerController) Stop() error {
2016-02-22 00:13:08 +00:00
// Stop is invoked from the http endpoint.
lbc.stopLock.Lock()
defer lbc.stopLock.Unlock()
// Only try draining the workqueue if we haven't already.
if !lbc.shutdown {
lbc.removeFromIngress()
2016-02-22 00:13:08 +00:00
close(lbc.stopCh)
glog.Infof("shutting down controller queues")
2016-02-22 00:13:08 +00:00
lbc.shutdown = true
lbc.syncQueue.shutdown()
return nil
}
return fmt.Errorf("shutdown already in progress")
}
func (lbc *loadBalancerController) removeFromIngress() {
ings := lbc.ingLister.Store.List()
glog.Infof("updating %v Ingress rule/s", len(ings))
for _, cur := range ings {
ing := cur.(*extensions.Ingress)
ingClient := lbc.client.Extensions().Ingress(ing.Namespace)
currIng, err := ingClient.Get(ing.Name)
if err != nil {
glog.Errorf("unexpected error searching Ingress %v/%v: %v", ing.Namespace, ing.Name, err)
continue
}
lbIPs := ing.Status.LoadBalancer.Ingress
if len(lbIPs) > 0 && lbc.isStatusIPDefined(lbIPs) {
2016-04-06 14:46:06 +00:00
glog.Infof("Updating loadbalancer %v/%v. Removing IP %v", ing.Namespace, ing.Name, lbc.podInfo.NodeIP)
for idx, lbStatus := range currIng.Status.LoadBalancer.Ingress {
2016-04-06 14:46:06 +00:00
if lbStatus.IP == lbc.podInfo.NodeIP {
currIng.Status.LoadBalancer.Ingress = append(currIng.Status.LoadBalancer.Ingress[:idx],
currIng.Status.LoadBalancer.Ingress[idx+1:]...)
break
}
}
if _, err := ingClient.UpdateStatus(currIng); err != nil {
lbc.recorder.Eventf(currIng, api.EventTypeWarning, "UPDATE", "error: %v", err)
continue
}
2016-04-06 14:46:06 +00:00
lbc.recorder.Eventf(currIng, api.EventTypeNormal, "DELETE", "ip: %v", lbc.podInfo.NodeIP)
}
2016-02-22 00:13:08 +00:00
}
}
// Run starts the loadbalancer controller.
func (lbc *loadBalancerController) Run() {
glog.Infof("starting NGINX loadbalancer controller")
go lbc.nginx.Start()
2016-02-22 00:13:08 +00:00
go lbc.ingController.Run(lbc.stopCh)
go lbc.endpController.Run(lbc.stopCh)
go lbc.svcController.Run(lbc.stopCh)
time.Sleep(1 * time.Second)
go lbc.syncQueue.run(time.Second, lbc.stopCh)
2016-03-31 17:59:28 +00:00
go lbc.ingQueue.run(time.Second, lbc.stopCh)
2016-04-14 23:42:37 +00:00
go lbc.svcEpQueue.run(time.Second, lbc.stopCh)
2016-02-22 00:13:08 +00:00
<-lbc.stopCh
glog.Infof("shutting down NGINX loadbalancer controller")
2016-02-22 00:13:08 +00:00
}