1155 lines
32 KiB
Go
1155 lines
32 KiB
Go
/*
|
|
Copyright 2016 The Kubernetes Authors.
|
|
|
|
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 cloud
|
|
|
|
import (
|
|
"context"
|
|
"errors"
|
|
"reflect"
|
|
"testing"
|
|
"time"
|
|
|
|
"k8s.io/api/core/v1"
|
|
"k8s.io/client-go/kubernetes/fake"
|
|
"k8s.io/client-go/kubernetes/scheme"
|
|
|
|
metav1 "k8s.io/apimachinery/pkg/apis/meta/v1"
|
|
"k8s.io/apimachinery/pkg/types"
|
|
"k8s.io/client-go/informers"
|
|
"k8s.io/client-go/tools/record"
|
|
"k8s.io/cloud-provider"
|
|
fakecloud "k8s.io/cloud-provider/fake"
|
|
"k8s.io/kubernetes/pkg/controller/testutil"
|
|
kubeletapis "k8s.io/kubernetes/pkg/kubelet/apis"
|
|
schedulerapi "k8s.io/kubernetes/pkg/scheduler/api"
|
|
|
|
"github.com/stretchr/testify/assert"
|
|
"k8s.io/klog"
|
|
)
|
|
|
|
func TestEnsureNodeExistsByProviderID(t *testing.T) {
|
|
|
|
testCases := []struct {
|
|
testName string
|
|
node *v1.Node
|
|
expectedCalls []string
|
|
expectedNodeExists bool
|
|
hasInstanceID bool
|
|
existsByProviderID bool
|
|
nodeNameErr error
|
|
providerIDErr error
|
|
}{
|
|
{
|
|
testName: "node exists by provider id",
|
|
existsByProviderID: true,
|
|
providerIDErr: nil,
|
|
hasInstanceID: true,
|
|
nodeNameErr: errors.New("unimplemented"),
|
|
expectedCalls: []string{"instance-exists-by-provider-id"},
|
|
expectedNodeExists: true,
|
|
node: &v1.Node{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
ProviderID: "node0",
|
|
},
|
|
},
|
|
},
|
|
{
|
|
testName: "does not exist by provider id",
|
|
existsByProviderID: false,
|
|
providerIDErr: nil,
|
|
hasInstanceID: true,
|
|
nodeNameErr: errors.New("unimplemented"),
|
|
expectedCalls: []string{"instance-exists-by-provider-id"},
|
|
expectedNodeExists: false,
|
|
node: &v1.Node{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
ProviderID: "node0",
|
|
},
|
|
},
|
|
},
|
|
{
|
|
testName: "exists by instance id",
|
|
existsByProviderID: true,
|
|
providerIDErr: nil,
|
|
hasInstanceID: true,
|
|
nodeNameErr: nil,
|
|
expectedCalls: []string{"instance-id", "instance-exists-by-provider-id"},
|
|
expectedNodeExists: true,
|
|
node: &v1.Node{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
},
|
|
},
|
|
},
|
|
{
|
|
testName: "does not exist by no instance id",
|
|
existsByProviderID: true,
|
|
providerIDErr: nil,
|
|
hasInstanceID: false,
|
|
nodeNameErr: cloudprovider.InstanceNotFound,
|
|
expectedCalls: []string{"instance-id"},
|
|
expectedNodeExists: false,
|
|
node: &v1.Node{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
},
|
|
},
|
|
},
|
|
{
|
|
testName: "provider id returns error",
|
|
existsByProviderID: false,
|
|
providerIDErr: errors.New("unimplemented"),
|
|
hasInstanceID: true,
|
|
nodeNameErr: cloudprovider.InstanceNotFound,
|
|
expectedCalls: []string{"instance-exists-by-provider-id"},
|
|
expectedNodeExists: false,
|
|
node: &v1.Node{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
ProviderID: "node0",
|
|
},
|
|
},
|
|
},
|
|
}
|
|
|
|
for _, tc := range testCases {
|
|
t.Run(tc.testName, func(t *testing.T) {
|
|
fc := &fakecloud.Cloud{
|
|
ExistsByProviderID: tc.existsByProviderID,
|
|
Err: tc.nodeNameErr,
|
|
ErrByProviderID: tc.providerIDErr,
|
|
}
|
|
|
|
if tc.hasInstanceID {
|
|
fc.ExtID = map[types.NodeName]string{
|
|
types.NodeName(tc.node.Name): "provider-id://a",
|
|
}
|
|
}
|
|
|
|
instances, _ := fc.Instances()
|
|
exists, err := ensureNodeExistsByProviderID(context.TODO(), instances, tc.node)
|
|
assert.Equal(t, err, tc.providerIDErr)
|
|
|
|
assert.EqualValues(t, tc.expectedCalls, fc.Calls,
|
|
"expected cloud provider methods `%v` to be called but `%v` was called ",
|
|
tc.expectedCalls, fc.Calls)
|
|
|
|
assert.Equal(t, tc.expectedNodeExists, exists,
|
|
"expected exists to be `%t` but got `%t`",
|
|
tc.existsByProviderID, exists)
|
|
})
|
|
}
|
|
|
|
}
|
|
|
|
// This test checks that a node with the external cloud provider taint is cloudprovider initialized
|
|
func TestNodeInitialized(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: schedulerapi.TaintExternalCloudProvider,
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{
|
|
types.NodeName("node0"): "t1.micro",
|
|
},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
nodeStatusUpdateFrequency: 1 * time.Second,
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
|
|
assert.Equal(t, 1, len(fnh.UpdatedNodes), "Node was not updated")
|
|
assert.Equal(t, "node0", fnh.UpdatedNodes[0].Name, "Node was not updated")
|
|
assert.Equal(t, 0, len(fnh.UpdatedNodes[0].Spec.Taints), "Node Taint was not removed after cloud init")
|
|
}
|
|
|
|
// This test checks that a node without the external cloud provider taint are NOT cloudprovider initialized
|
|
func TestNodeIgnored(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{
|
|
types.NodeName("node0"): "t1.micro",
|
|
},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
assert.Equal(t, 0, len(fnh.UpdatedNodes), "Node was wrongly updated")
|
|
|
|
}
|
|
|
|
// This test checks that a node with the external cloud provider taint is cloudprovider initialized and
|
|
// the GCE route condition is added if cloudprovider is GCE
|
|
func TestGCECondition(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: schedulerapi.TaintExternalCloudProvider,
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{
|
|
types.NodeName("node0"): "t1.micro",
|
|
},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Provider: "gce",
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
|
|
assert.Equal(t, 1, len(fnh.UpdatedNodes), "Node was not updated")
|
|
assert.Equal(t, "node0", fnh.UpdatedNodes[0].Name, "Node was not updated")
|
|
assert.Equal(t, 2, len(fnh.UpdatedNodes[0].Status.Conditions), "No new conditions were added for GCE")
|
|
|
|
conditionAdded := false
|
|
for _, cond := range fnh.UpdatedNodes[0].Status.Conditions {
|
|
if cond.Status == "True" && cond.Type == "NetworkUnavailable" && cond.Reason == "NoRouteCreated" {
|
|
conditionAdded = true
|
|
}
|
|
}
|
|
|
|
assert.True(t, conditionAdded, "Network Route Condition for GCE not added by external cloud initializer")
|
|
}
|
|
|
|
// This test checks that a node with the external cloud provider taint is cloudprovider initialized and
|
|
// and that zone labels are added correctly
|
|
func TestZoneInitialized(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
Labels: map[string]string{},
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: schedulerapi.TaintExternalCloudProvider,
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{
|
|
types.NodeName("node0"): "t1.micro",
|
|
},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Provider: "aws",
|
|
Zone: cloudprovider.Zone{
|
|
FailureDomain: "us-west-1a",
|
|
Region: "us-west",
|
|
},
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
|
|
assert.Equal(t, 1, len(fnh.UpdatedNodes), "Node was not updated")
|
|
assert.Equal(t, "node0", fnh.UpdatedNodes[0].Name, "Node was not updated")
|
|
assert.Equal(t, 4, len(fnh.UpdatedNodes[0].ObjectMeta.Labels),
|
|
"Node label for Region and Zone were not set")
|
|
assert.Equal(t, "us-west", fnh.UpdatedNodes[0].ObjectMeta.Labels[v1.LabelZoneRegionStable],
|
|
"Node Region not correctly updated")
|
|
assert.Equal(t, "us-west-1a", fnh.UpdatedNodes[0].ObjectMeta.Labels[v1.LabelZoneFailureDomainStable],
|
|
"Node FailureDomain not correctly updated")
|
|
assert.Equal(t, "us-west", fnh.UpdatedNodes[0].ObjectMeta.Labels[v1.LabelZoneRegion],
|
|
"Node Region not correctly updated")
|
|
assert.Equal(t, "us-west-1a", fnh.UpdatedNodes[0].ObjectMeta.Labels[v1.LabelZoneFailureDomain],
|
|
"Node FailureDomain not correctly updated")
|
|
}
|
|
|
|
// This test checks that a node with the external cloud provider taint is cloudprovider initialized and
|
|
// and nodeAddresses are updated from the cloudprovider
|
|
func TestNodeAddresses(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
Labels: map[string]string{},
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: "ImproveCoverageTaint",
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
{
|
|
Key: schedulerapi.TaintExternalCloudProvider,
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Provider: "aws",
|
|
Zone: cloudprovider.Zone{
|
|
FailureDomain: "us-west-1a",
|
|
Region: "us-west",
|
|
},
|
|
ExistsByProviderID: true,
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
nodeStatusUpdateFrequency: 1 * time.Second,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
|
|
assert.Equal(t, 1, len(fnh.UpdatedNodes), "Node was not updated")
|
|
assert.Equal(t, "node0", fnh.UpdatedNodes[0].Name, "Node was not updated")
|
|
assert.Equal(t, 3, len(fnh.UpdatedNodes[0].Status.Addresses), "Node status not updated")
|
|
|
|
fakeCloud.Addresses = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
}
|
|
|
|
cloudNodeController.UpdateNodeStatus(context.TODO())
|
|
|
|
updatedNodes := fnh.GetUpdatedNodesCopy()
|
|
|
|
assert.Equal(t, 2, len(updatedNodes[0].Status.Addresses), "Node Addresses not correctly updated")
|
|
|
|
}
|
|
|
|
// This test checks that a node with the external cloud provider taint is cloudprovider initialized and
|
|
// and the provided node ip is validated with the cloudprovider and nodeAddresses are updated from the cloudprovider
|
|
func TestNodeProvidedIPAddresses(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
Labels: map[string]string{},
|
|
Annotations: map[string]string{
|
|
kubeletapis.AnnotationProvidedIPAddr: "10.0.0.1",
|
|
},
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: "ImproveCoverageTaint",
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
{
|
|
Key: schedulerapi.TaintExternalCloudProvider,
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
ProviderID: "node0.aws.12345",
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{
|
|
types.NodeName("node0"): "t1.micro",
|
|
types.NodeName("node0.aws.12345"): "t2.macro",
|
|
},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Provider: "aws",
|
|
Zone: cloudprovider.Zone{
|
|
FailureDomain: "us-west-1a",
|
|
Region: "us-west",
|
|
},
|
|
ExistsByProviderID: true,
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
nodeStatusUpdateFrequency: 1 * time.Second,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
|
|
assert.Equal(t, 1, len(fnh.UpdatedNodes), "Node was not updated")
|
|
assert.Equal(t, "node0", fnh.UpdatedNodes[0].Name, "Node was not updated")
|
|
assert.Equal(t, 3, len(fnh.UpdatedNodes[0].Status.Addresses), "Node status unexpectedly updated")
|
|
|
|
cloudNodeController.UpdateNodeStatus(context.TODO())
|
|
|
|
updatedNodes := fnh.GetUpdatedNodesCopy()
|
|
|
|
assert.Equal(t, 3, len(updatedNodes[0].Status.Addresses), "Node Addresses not correctly updated")
|
|
assert.Equal(t, "10.0.0.1", updatedNodes[0].Status.Addresses[0].Address, "Node Addresses not correctly updated")
|
|
}
|
|
|
|
func Test_reconcileNodeLabels(t *testing.T) {
|
|
testcases := []struct {
|
|
name string
|
|
labels map[string]string
|
|
expectedLabels map[string]string
|
|
expectedErr error
|
|
}{
|
|
{
|
|
name: "requires reconcile",
|
|
labels: map[string]string{
|
|
v1.LabelZoneFailureDomain: "foo",
|
|
v1.LabelZoneRegion: "bar",
|
|
v1.LabelInstanceType: "the-best-type",
|
|
},
|
|
expectedLabels: map[string]string{
|
|
v1.LabelZoneFailureDomain: "foo",
|
|
v1.LabelZoneRegion: "bar",
|
|
v1.LabelZoneFailureDomainStable: "foo",
|
|
v1.LabelZoneRegionStable: "bar",
|
|
v1.LabelInstanceType: "the-best-type",
|
|
v1.LabelInstanceTypeStable: "the-best-type",
|
|
},
|
|
expectedErr: nil,
|
|
},
|
|
{
|
|
name: "doesn't require reconcile",
|
|
labels: map[string]string{
|
|
v1.LabelZoneFailureDomain: "foo",
|
|
v1.LabelZoneRegion: "bar",
|
|
v1.LabelZoneFailureDomainStable: "foo",
|
|
v1.LabelZoneRegionStable: "bar",
|
|
v1.LabelInstanceType: "the-best-type",
|
|
v1.LabelInstanceTypeStable: "the-best-type",
|
|
},
|
|
expectedLabels: map[string]string{
|
|
v1.LabelZoneFailureDomain: "foo",
|
|
v1.LabelZoneRegion: "bar",
|
|
v1.LabelZoneFailureDomainStable: "foo",
|
|
v1.LabelZoneRegionStable: "bar",
|
|
v1.LabelInstanceType: "the-best-type",
|
|
v1.LabelInstanceTypeStable: "the-best-type",
|
|
},
|
|
expectedErr: nil,
|
|
},
|
|
{
|
|
name: "require reconcile -- secondary labels are different from primary",
|
|
labels: map[string]string{
|
|
v1.LabelZoneFailureDomain: "foo",
|
|
v1.LabelZoneRegion: "bar",
|
|
v1.LabelZoneFailureDomainStable: "wrongfoo",
|
|
v1.LabelZoneRegionStable: "wrongbar",
|
|
v1.LabelInstanceType: "the-best-type",
|
|
v1.LabelInstanceTypeStable: "the-wrong-type",
|
|
},
|
|
expectedLabels: map[string]string{
|
|
v1.LabelZoneFailureDomain: "foo",
|
|
v1.LabelZoneRegion: "bar",
|
|
v1.LabelZoneFailureDomainStable: "foo",
|
|
v1.LabelZoneRegionStable: "bar",
|
|
v1.LabelInstanceType: "the-best-type",
|
|
v1.LabelInstanceTypeStable: "the-best-type",
|
|
},
|
|
expectedErr: nil,
|
|
},
|
|
}
|
|
|
|
for _, test := range testcases {
|
|
t.Run(test.name, func(t *testing.T) {
|
|
testNode := &v1.Node{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node01",
|
|
Labels: test.labels,
|
|
},
|
|
}
|
|
|
|
clientset := fake.NewSimpleClientset(testNode)
|
|
factory := informers.NewSharedInformerFactory(clientset, 0)
|
|
|
|
cnc := &CloudNodeController{
|
|
kubeClient: clientset,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
}
|
|
|
|
// activate node informer
|
|
factory.Core().V1().Nodes().Informer()
|
|
factory.Start(nil)
|
|
factory.WaitForCacheSync(nil)
|
|
|
|
err := cnc.reconcileNodeLabels("node01")
|
|
if err != test.expectedErr {
|
|
t.Logf("actual err: %v", err)
|
|
t.Logf("expected err: %v", test.expectedErr)
|
|
t.Errorf("unexpected error")
|
|
}
|
|
|
|
actualNode, err := clientset.CoreV1().Nodes().Get("node01", metav1.GetOptions{})
|
|
if err != nil {
|
|
t.Fatalf("error getting updated node: %v", err)
|
|
}
|
|
|
|
if !reflect.DeepEqual(actualNode.Labels, test.expectedLabels) {
|
|
t.Logf("actual node labels: %v", actualNode.Labels)
|
|
t.Logf("expected node labels: %v", test.expectedLabels)
|
|
t.Errorf("updated node did not match expected node")
|
|
}
|
|
})
|
|
}
|
|
|
|
}
|
|
|
|
// Tests that node address changes are detected correctly
|
|
func TestNodeAddressesChangeDetected(t *testing.T) {
|
|
addressSet1 := []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
}
|
|
addressSet2 := []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
}
|
|
|
|
assert.False(t, nodeAddressesChangeDetected(addressSet1, addressSet2),
|
|
"Node address changes are not detected correctly")
|
|
|
|
addressSet1 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.164",
|
|
},
|
|
}
|
|
addressSet2 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
}
|
|
|
|
assert.True(t, nodeAddressesChangeDetected(addressSet1, addressSet2),
|
|
"Node address changes are not detected correctly")
|
|
|
|
addressSet1 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.164",
|
|
},
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "hostname.zone.region.aws.test",
|
|
},
|
|
}
|
|
addressSet2 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.164",
|
|
},
|
|
}
|
|
|
|
assert.True(t, nodeAddressesChangeDetected(addressSet1, addressSet2),
|
|
"Node address changes are not detected correctly")
|
|
|
|
addressSet1 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.164",
|
|
},
|
|
}
|
|
addressSet2 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.164",
|
|
},
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "hostname.zone.region.aws.test",
|
|
},
|
|
}
|
|
|
|
assert.True(t, nodeAddressesChangeDetected(addressSet1, addressSet2),
|
|
"Node address changes are not detected correctly")
|
|
|
|
addressSet1 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
}
|
|
addressSet2 = []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
}
|
|
|
|
assert.True(t, nodeAddressesChangeDetected(addressSet1, addressSet2),
|
|
"Node address changes are not detected correctly")
|
|
}
|
|
|
|
// This test checks that a node with the external cloud provider taint is cloudprovider initialized and
|
|
// and node addresses will not be updated when node isn't present according to the cloudprovider
|
|
func TestNodeAddressesNotUpdate(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
Labels: map[string]string{},
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: "ImproveCoverageTaint",
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
ExistsByProviderID: false,
|
|
Err: nil,
|
|
}
|
|
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
}
|
|
|
|
cloudNodeController.updateNodeAddress(context.TODO(), fnh.Existing[0], fakeCloud)
|
|
|
|
if len(fnh.UpdatedNodes) != 0 {
|
|
t.Errorf("Node was not correctly updated, the updated len(nodes) got: %v, wanted=0", len(fnh.UpdatedNodes))
|
|
}
|
|
}
|
|
|
|
// This test checks that a node is set with the correct providerID
|
|
func TestNodeProviderID(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
Labels: map[string]string{},
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: "ImproveCoverageTaint",
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
{
|
|
Key: schedulerapi.TaintExternalCloudProvider,
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Provider: "test",
|
|
ExtID: map[types.NodeName]string{
|
|
types.NodeName("node0"): "12345",
|
|
},
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
nodeStatusUpdateFrequency: 1 * time.Second,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
|
|
assert.Equal(t, 1, len(fnh.UpdatedNodes), "Node was not updated")
|
|
assert.Equal(t, "node0", fnh.UpdatedNodes[0].Name, "Node was not updated")
|
|
assert.Equal(t, "test://12345", fnh.UpdatedNodes[0].Spec.ProviderID, "Node ProviderID not set correctly")
|
|
}
|
|
|
|
// This test checks that a node's provider ID will not be overwritten
|
|
func TestNodeProviderIDAlreadySet(t *testing.T) {
|
|
fnh := &testutil.FakeNodeHandler{
|
|
Existing: []*v1.Node{
|
|
{
|
|
ObjectMeta: metav1.ObjectMeta{
|
|
Name: "node0",
|
|
CreationTimestamp: metav1.Date(2012, 1, 1, 0, 0, 0, 0, time.UTC),
|
|
Labels: map[string]string{},
|
|
},
|
|
Status: v1.NodeStatus{
|
|
Conditions: []v1.NodeCondition{
|
|
{
|
|
Type: v1.NodeReady,
|
|
Status: v1.ConditionUnknown,
|
|
LastHeartbeatTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
LastTransitionTime: metav1.Date(2015, 1, 1, 12, 0, 0, 0, time.UTC),
|
|
},
|
|
},
|
|
},
|
|
Spec: v1.NodeSpec{
|
|
ProviderID: "test-provider-id",
|
|
Taints: []v1.Taint{
|
|
{
|
|
Key: "ImproveCoverageTaint",
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
{
|
|
Key: schedulerapi.TaintExternalCloudProvider,
|
|
Value: "true",
|
|
Effect: v1.TaintEffectNoSchedule,
|
|
},
|
|
},
|
|
},
|
|
},
|
|
},
|
|
Clientset: fake.NewSimpleClientset(&v1.PodList{}),
|
|
DeleteWaitChan: make(chan struct{}),
|
|
}
|
|
|
|
factory := informers.NewSharedInformerFactory(fnh, 0)
|
|
|
|
fakeCloud := &fakecloud.Cloud{
|
|
InstanceTypes: map[types.NodeName]string{},
|
|
Addresses: []v1.NodeAddress{
|
|
{
|
|
Type: v1.NodeHostName,
|
|
Address: "node0.cloud.internal",
|
|
},
|
|
{
|
|
Type: v1.NodeInternalIP,
|
|
Address: "10.0.0.1",
|
|
},
|
|
{
|
|
Type: v1.NodeExternalIP,
|
|
Address: "132.143.154.163",
|
|
},
|
|
},
|
|
Provider: "test",
|
|
ExtID: map[types.NodeName]string{
|
|
types.NodeName("node0"): "12345",
|
|
},
|
|
Err: nil,
|
|
}
|
|
|
|
eventBroadcaster := record.NewBroadcaster()
|
|
cloudNodeController := &CloudNodeController{
|
|
kubeClient: fnh,
|
|
nodeInformer: factory.Core().V1().Nodes(),
|
|
cloud: fakeCloud,
|
|
nodeStatusUpdateFrequency: 1 * time.Second,
|
|
recorder: eventBroadcaster.NewRecorder(scheme.Scheme, v1.EventSource{Component: "cloud-node-controller"}),
|
|
}
|
|
eventBroadcaster.StartLogging(klog.Infof)
|
|
|
|
cloudNodeController.AddCloudNode(context.TODO(), fnh.Existing[0])
|
|
|
|
assert.Equal(t, 1, len(fnh.UpdatedNodes), "Node was not updated")
|
|
assert.Equal(t, "node0", fnh.UpdatedNodes[0].Name, "Node was not updated")
|
|
// CCM node controller should not overwrite provider if it's already set
|
|
assert.Equal(t, "test-provider-id", fnh.UpdatedNodes[0].Spec.ProviderID, "Node ProviderID not set correctly")
|
|
}
|