Merge pull request #1347 from tariq1890/add_linter

add more linters and improve code quality
This commit is contained in:
Kubernetes Prow Robot 2020-01-09 01:07:45 -08:00 committed by GitHub
commit 6c49ebb89f
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
26 changed files with 70 additions and 77 deletions

View File

@ -17,3 +17,6 @@ linters:
- ineffassign - ineffassign
- golint - golint
- goimports - goimports
- misspell
- unconvert
- staticcheck

View File

@ -63,8 +63,8 @@ func SameEndpoints(a, b []*endpoint.Endpoint) bool {
return false return false
} }
sa := a[:] sa := a
sb := b[:] sb := b
sort.Sort(byAllFields(sa)) sort.Sort(byAllFields(sa))
sort.Sort(byAllFields(sb)) sort.Sort(byAllFields(sb))
@ -82,8 +82,8 @@ func SameEndpointLabels(a, b []*endpoint.Endpoint) bool {
return false return false
} }
sa := a[:] sa := a
sb := b[:] sb := b
sort.Sort(byAllFields(sa)) sort.Sort(byAllFields(sa))
sort.Sort(byAllFields(sb)) sort.Sort(byAllFields(sb))

View File

@ -237,10 +237,10 @@ func (p *AlibabaCloudProvider) refreshStsToken(sleepTime time.Duration) {
sleepTime = p.nextExpire.Sub(nowTime) sleepTime = p.nextExpire.Sub(nowTime)
p.clientLock.RUnlock() p.clientLock.RUnlock()
log.Infof("Distance expiration time %v", sleepTime) log.Infof("Distance expiration time %v", sleepTime)
if sleepTime < time.Duration(10*time.Minute) { if sleepTime < 10*time.Minute {
sleepTime = time.Duration(time.Second * 1) sleepTime = time.Second * 1
} else { } else {
sleepTime = time.Duration(9 * time.Minute) sleepTime = 9 * time.Minute
log.Info("Next fetch sts sleep interval : ", sleepTime.String()) log.Info("Next fetch sts sleep interval : ", sleepTime.String())
continue continue
} }

View File

@ -749,9 +749,9 @@ func canonicalHostedZone(hostname string) string {
} }
// cleanZoneID removes the "/hostedzone/" prefix // cleanZoneID removes the "/hostedzone/" prefix
func cleanZoneID(ID string) string { func cleanZoneID(id string) string {
if strings.HasPrefix(ID, "/hostedzone/") { if strings.HasPrefix(id, "/hostedzone/") {
ID = strings.TrimPrefix(ID, "/hostedzone/") id = strings.TrimPrefix(id, "/hostedzone/")
} }
return ID return id
} }

View File

@ -283,16 +283,14 @@ func (p *AWSSDProvider) submitCreates(namespaces []*sd.NamespaceSummary, changes
} }
// update local list of services // update local list of services
services[*srv.Name] = srv services[*srv.Name] = srv
} else { } else if (ch.RecordTTL.IsConfigured() && *srv.DnsConfig.DnsRecords[0].TTL != int64(ch.RecordTTL)) ||
// update service when TTL or Description differ
if (ch.RecordTTL.IsConfigured() && *srv.DnsConfig.DnsRecords[0].TTL != int64(ch.RecordTTL)) ||
aws.StringValue(srv.Description) != ch.Labels[endpoint.AWSSDDescriptionLabel] { aws.StringValue(srv.Description) != ch.Labels[endpoint.AWSSDDescriptionLabel] {
// update service when TTL or Description differ
err = p.UpdateService(srv, ch) err = p.UpdateService(srv, ch)
if err != nil { if err != nil {
return err return err
} }
} }
}
err = p.RegisterInstance(srv, ch) err = p.RegisterInstance(srv, ch)
if err != nil { if err != nil {
@ -442,13 +440,13 @@ func (p *AWSSDProvider) CreateService(namespaceID *string, srvName *string, ep *
Name: srvName, Name: srvName,
Description: aws.String(ep.Labels[endpoint.AWSSDDescriptionLabel]), Description: aws.String(ep.Labels[endpoint.AWSSDDescriptionLabel]),
DnsConfig: &sd.DnsConfig{ DnsConfig: &sd.DnsConfig{
NamespaceId: namespaceID,
RoutingPolicy: aws.String(routingPolicy), RoutingPolicy: aws.String(routingPolicy),
DnsRecords: []*sd.DnsRecord{{ DnsRecords: []*sd.DnsRecord{{
Type: aws.String(srvType), Type: aws.String(srvType),
TTL: aws.Int64(ttl), TTL: aws.Int64(ttl),
}}, }},
}, },
NamespaceId: namespaceID,
}) })
if err != nil { if err != nil {
return nil, err return nil, err

View File

@ -59,10 +59,10 @@ func (s *AWSSDClientStub) CreateService(input *sd.CreateServiceInput) (*sd.Creat
CreatorRequestId: input.CreatorRequestId, CreatorRequestId: input.CreatorRequestId,
} }
nsServices, ok := s.services[*input.DnsConfig.NamespaceId] nsServices, ok := s.services[*input.NamespaceId]
if !ok { if !ok {
nsServices = make(map[string]*sd.Service) nsServices = make(map[string]*sd.Service)
s.services[*input.DnsConfig.NamespaceId] = nsServices s.services[*input.NamespaceId] = nsServices
} }
nsServices[*srv.Id] = srv nsServices[*srv.Id] = srv
@ -539,13 +539,13 @@ func TestAWSSDProvider_CreateService(t *testing.T) {
expectedServices["A-srv"] = &sd.Service{ expectedServices["A-srv"] = &sd.Service{
Name: aws.String("A-srv"), Name: aws.String("A-srv"),
DnsConfig: &sd.DnsConfig{ DnsConfig: &sd.DnsConfig{
NamespaceId: aws.String("private"),
RoutingPolicy: aws.String(sd.RoutingPolicyMultivalue), RoutingPolicy: aws.String(sd.RoutingPolicyMultivalue),
DnsRecords: []*sd.DnsRecord{{ DnsRecords: []*sd.DnsRecord{{
Type: aws.String(sd.RecordTypeA), Type: aws.String(sd.RecordTypeA),
TTL: aws.Int64(60), TTL: aws.Int64(60),
}}, }},
}, },
NamespaceId: aws.String("private"),
} }
// CNAME type // CNAME type
@ -557,13 +557,13 @@ func TestAWSSDProvider_CreateService(t *testing.T) {
expectedServices["CNAME-srv"] = &sd.Service{ expectedServices["CNAME-srv"] = &sd.Service{
Name: aws.String("CNAME-srv"), Name: aws.String("CNAME-srv"),
DnsConfig: &sd.DnsConfig{ DnsConfig: &sd.DnsConfig{
NamespaceId: aws.String("private"),
RoutingPolicy: aws.String(sd.RoutingPolicyWeighted), RoutingPolicy: aws.String(sd.RoutingPolicyWeighted),
DnsRecords: []*sd.DnsRecord{{ DnsRecords: []*sd.DnsRecord{{
Type: aws.String(sd.RecordTypeCname), Type: aws.String(sd.RecordTypeCname),
TTL: aws.Int64(80), TTL: aws.Int64(80),
}}, }},
}, },
NamespaceId: aws.String("private"),
} }
// ALIAS type // ALIAS type
@ -575,13 +575,13 @@ func TestAWSSDProvider_CreateService(t *testing.T) {
expectedServices["ALIAS-srv"] = &sd.Service{ expectedServices["ALIAS-srv"] = &sd.Service{
Name: aws.String("ALIAS-srv"), Name: aws.String("ALIAS-srv"),
DnsConfig: &sd.DnsConfig{ DnsConfig: &sd.DnsConfig{
NamespaceId: aws.String("private"),
RoutingPolicy: aws.String(sd.RoutingPolicyWeighted), RoutingPolicy: aws.String(sd.RoutingPolicyWeighted),
DnsRecords: []*sd.DnsRecord{{ DnsRecords: []*sd.DnsRecord{{
Type: aws.String(sd.RecordTypeA), Type: aws.String(sd.RecordTypeA),
TTL: aws.Int64(100), TTL: aws.Int64(100),
}}, }},
}, },
NamespaceId: aws.String("private"),
} }
validateAWSSDServicesMapsEqual(t, expectedServices, api.services["private"]) validateAWSSDServicesMapsEqual(t, expectedServices, api.services["private"])

View File

@ -75,7 +75,7 @@ func NewRoute53APIStub() *Route53APIStub {
func (r *Route53APIStub) ListResourceRecordSetsPages(input *route53.ListResourceRecordSetsInput, fn func(p *route53.ListResourceRecordSetsOutput, lastPage bool) (shouldContinue bool)) error { func (r *Route53APIStub) ListResourceRecordSetsPages(input *route53.ListResourceRecordSetsInput, fn func(p *route53.ListResourceRecordSetsOutput, lastPage bool) (shouldContinue bool)) error {
output := route53.ListResourceRecordSetsOutput{} // TODO: Support optional input args. output := route53.ListResourceRecordSetsOutput{} // TODO: Support optional input args.
if len(r.recordSets) <= 0 { if len(r.recordSets) == 0 {
output.ResourceRecordSets = []*route53.ResourceRecordSet{} output.ResourceRecordSets = []*route53.ResourceRecordSet{}
} else if _, ok := r.recordSets[aws.StringValue(input.HostedZoneId)]; !ok { } else if _, ok := r.recordSets[aws.StringValue(input.HostedZoneId)]; !ok {
output.ResourceRecordSets = []*route53.ResourceRecordSet{} output.ResourceRecordSets = []*route53.ResourceRecordSet{}

View File

@ -149,7 +149,7 @@ func getAccessToken(cfg config, environment azure.Environment) (*adal.ServicePri
return token, nil return token, nil
} }
// Try to retrive token with MSI. // Try to retrieve token with MSI.
if cfg.UseManagedIdentityExtension { if cfg.UseManagedIdentityExtension {
log.Info("Using managed identity extension to retrieve access token for Azure API.") log.Info("Using managed identity extension to retrieve access token for Azure API.")
msiEndpoint, err := adal.GetMSIVMEndpoint() msiEndpoint, err := adal.GetMSIVMEndpoint()
@ -193,7 +193,7 @@ func (p *AzureProvider) Records() (endpoints []*endpoint.Endpoint, _ error) {
log.Error("Skipping invalid record set with nil name or type.") log.Error("Skipping invalid record set with nil name or type.")
return true return true
} }
recordType := strings.TrimLeft(*recordSet.Type, "Microsoft.Network/dnszones/") recordType := strings.TrimPrefix(*recordSet.Type, "Microsoft.Network/dnszones/")
if !supportedRecordType(recordType) { if !supportedRecordType(recordType) {
return true return true
} }
@ -208,7 +208,7 @@ func (p *AzureProvider) Records() (endpoints []*endpoint.Endpoint, _ error) {
ttl = endpoint.TTL(*recordSet.TTL) ttl = endpoint.TTL(*recordSet.TTL)
} }
ep := endpoint.NewEndpointWithTTL(name, recordType, endpoint.TTL(ttl), targets...) ep := endpoint.NewEndpointWithTTL(name, recordType, ttl, targets...)
log.Debugf( log.Debugf(
"Found %s record for '%s' with target '%s'.", "Found %s record for '%s' with target '%s'.",
ep.RecordType, ep.RecordType,

View File

@ -106,7 +106,7 @@ func (p *AzurePrivateDNSProvider) Records() (endpoints []*endpoint.Endpoint, _ e
log.Debugf("Skipping invalid record set with missing type.") log.Debugf("Skipping invalid record set with missing type.")
return return
} }
recordType = strings.TrimLeft(*recordSet.Type, "Microsoft.Network/privateDnsZones") recordType = strings.TrimPrefix(*recordSet.Type, "Microsoft.Network/privateDnsZones")
var name string var name string
if recordSet.Name == nil { if recordSet.Name == nil {
@ -126,7 +126,7 @@ func (p *AzurePrivateDNSProvider) Records() (endpoints []*endpoint.Endpoint, _ e
ttl = endpoint.TTL(*recordSet.TTL) ttl = endpoint.TTL(*recordSet.TTL)
} }
ep := endpoint.NewEndpointWithTTL(name, recordType, endpoint.TTL(ttl), targets...) ep := endpoint.NewEndpointWithTTL(name, recordType, ttl, targets...)
log.Debugf( log.Debugf(
"Found %s record for '%s' with target '%s'.", "Found %s record for '%s' with target '%s'.",
ep.RecordType, ep.RecordType,

View File

@ -54,7 +54,7 @@ func (m *mockPrivateZoneListResultPageIterator) getNextPage(context.Context, pri
// it assumed that instances of this kind of iterator are only skimmed through once per test // it assumed that instances of this kind of iterator are only skimmed through once per test
// otherwise a real implementation is required, e.g. based on a linked list // otherwise a real implementation is required, e.g. based on a linked list
if m.offset < len(m.results) { if m.offset < len(m.results) {
m.offset = m.offset + 1 m.offset++
return m.results[m.offset-1], nil return m.results[m.offset-1], nil
} }
@ -73,7 +73,7 @@ func (m *mockPrivateRecordSetListResultPageIterator) getNextPage(context.Context
// it assumed that instances of this kind of iterator are only skimmed through once per test // it assumed that instances of this kind of iterator are only skimmed through once per test
// otherwise a real implementation is required, e.g. based on a linked list // otherwise a real implementation is required, e.g. based on a linked list
if m.offset < len(m.results) { if m.offset < len(m.results) {
m.offset = m.offset + 1 m.offset++
return m.results[m.offset-1], nil return m.results[m.offset-1], nil
} }

View File

@ -56,7 +56,7 @@ func (m *mockZoneListResultPageIterator) getNextPage(context.Context, dns.ZoneLi
// it assumed that instances of this kind of iterator are only skimmed through once per test // it assumed that instances of this kind of iterator are only skimmed through once per test
// otherwise a real implementation is required, e.g. based on a linked list // otherwise a real implementation is required, e.g. based on a linked list
if m.offset < len(m.results) { if m.offset < len(m.results) {
m.offset = m.offset + 1 m.offset++
return m.results[m.offset-1], nil return m.results[m.offset-1], nil
} }
@ -75,7 +75,7 @@ func (m *mockRecordSetListResultPageIterator) getNextPage(context.Context, dns.R
// it assumed that instances of this kind of iterator are only skimmed through once per test // it assumed that instances of this kind of iterator are only skimmed through once per test
// otherwise a real implementation is required, e.g. based on a linked list // otherwise a real implementation is required, e.g. based on a linked list
if m.offset < len(m.results) { if m.offset < len(m.results) {
m.offset = m.offset + 1 m.offset++
return m.results[m.offset-1], nil return m.results[m.offset-1], nil
} }

View File

@ -62,7 +62,7 @@ func NewDigitalOceanProvider(domainFilter DomainFilter, dryRun bool) (*DigitalOc
if !ok { if !ok {
return nil, fmt.Errorf("No token found") return nil, fmt.Errorf("No token found")
} }
oauthClient := oauth2.NewClient(oauth2.NoContext, oauth2.StaticTokenSource(&oauth2.Token{ oauthClient := oauth2.NewClient(context.TODO(), oauth2.StaticTokenSource(&oauth2.Token{
AccessToken: token, AccessToken: token,
})) }))
client := godo.NewClient(oauthClient) client := godo.NewClient(oauthClient)

View File

@ -156,7 +156,7 @@ func (p *dnsimpleProvider) Zones() (map[string]dnsimple.Zone, error) {
return zones, nil return zones, nil
} }
// Records retuns a list of endpoints in a given zone // Records returns a list of endpoints in a given zone
func (p *dnsimpleProvider) Records() (endpoints []*endpoint.Endpoint, _ error) { func (p *dnsimpleProvider) Records() (endpoints []*endpoint.Endpoint, _ error) {
zones, err := p.Zones() zones, err := p.Zones()
if err != nil { if err != nil {

View File

@ -40,7 +40,7 @@ const (
// when rate limit is hit retry up to 5 times after sleep 1m between retries // when rate limit is hit retry up to 5 times after sleep 1m between retries
dynMaxRetriesOnErrRateLimited = 5 dynMaxRetriesOnErrRateLimited = 5
// two consecutive bad logins happen at least this many seconds appart // two consecutive bad logins happen at least this many seconds apart
// While it is easy to get the username right, misconfiguring the password // While it is easy to get the username right, misconfiguring the password
// can get account blocked. Exit(1) is not a good solution // can get account blocked. Exit(1) is not a good solution
// as k8s will restart the pod and another login attempt will be made // as k8s will restart the pod and another login attempt will be made
@ -51,7 +51,7 @@ const (
) )
func unixNow() int64 { func unixNow() int64 {
return int64(time.Now().Unix()) return time.Now().Unix()
} }
// DynConfig hold connection parameters to dyn.com and internal state // DynConfig hold connection parameters to dyn.com and internal state

View File

@ -320,7 +320,7 @@ func (p *GoogleProvider) submitChange(change *dns.Change) error {
return nil return nil
} }
// batchChange seperates a zone in multiple transaction. // batchChange separates a zone in multiple transaction.
func batchChange(change *dns.Change, batchSize int) []*dns.Change { func batchChange(change *dns.Change, batchSize int) []*dns.Change {
changes := []*dns.Change{} changes := []*dns.Change{}
@ -441,7 +441,7 @@ func newRecord(ep *endpoint.Endpoint) *dns.ResourceRecordSet {
targets[0] = ensureTrailingDot(targets[0]) targets[0] = ensureTrailingDot(targets[0])
} }
// no annotation results in a Ttl of 0, default to 300 for backwards-compatability // no annotation results in a Ttl of 0, default to 300 for backwards-compatibility
var ttl int64 = googleRecordTTL var ttl int64 = googleRecordTTL
if ep.RecordTTL.IsConfigured() { if ep.RecordTTL.IsConfigured() {
ttl = int64(ep.RecordTTL) ttl = int64(ep.RecordTTL)

View File

@ -108,7 +108,7 @@ func NewInfobloxProvider(infobloxConfig InfobloxConfig) (*InfobloxProvider, erro
var requestBuilder ibclient.HttpRequestBuilder var requestBuilder ibclient.HttpRequestBuilder
if infobloxConfig.MaxResults != 0 { if infobloxConfig.MaxResults != 0 {
// use our own HttpRequestBuilder which sets _max_results paramter on GET requests // use our own HttpRequestBuilder which sets _max_results parameter on GET requests
requestBuilder = NewMaxResultsRequestBuilder(infobloxConfig.MaxResults) requestBuilder = NewMaxResultsRequestBuilder(infobloxConfig.MaxResults)
} else { } else {
// use the default HttpRequestBuilder of the infoblox client // use the default HttpRequestBuilder of the infoblox client

View File

@ -168,7 +168,7 @@ func (client *mockIBConnector) GetObject(obj ibclient.IBObject, ref string, res
} }
func (client *mockIBConnector) DeleteObject(ref string) (refRes string, err error) { func (client *mockIBConnector) DeleteObject(ref string) (refRes string, err error) {
re, _ := regexp.Compile(`([^/]+)/[^:]+:([^/]+)/default`) re := regexp.MustCompile(`([^/]+)/[^:]+:([^/]+)/default`)
result := re.FindStringSubmatch(ref) result := re.FindStringSubmatch(ref)
switch result[1] { switch result[1] {

View File

@ -187,15 +187,13 @@ func (p *LinodeProvider) submitChanges(changes LinodeChanges) error {
if p.DryRun { if p.DryRun {
log.WithFields(logFields).Info("Would create record.") log.WithFields(logFields).Info("Would create record.")
} else { } else if _, err := p.Client.CreateDomainRecord(context.TODO(), change.Domain.ID, change.Options); err != nil {
if _, err := p.Client.CreateDomainRecord(context.TODO(), change.Domain.ID, change.Options); err != nil {
log.WithFields(logFields).Errorf( log.WithFields(logFields).Errorf(
"Failed to Create record: %v", "Failed to Create record: %v",
err, err,
) )
} }
} }
}
for _, change := range changes.Deletes { for _, change := range changes.Deletes {
logFields := log.Fields{ logFields := log.Fields{
@ -210,15 +208,13 @@ func (p *LinodeProvider) submitChanges(changes LinodeChanges) error {
if p.DryRun { if p.DryRun {
log.WithFields(logFields).Info("Would delete record.") log.WithFields(logFields).Info("Would delete record.")
} else { } else if err := p.Client.DeleteDomainRecord(context.TODO(), change.Domain.ID, change.DomainRecord.ID); err != nil {
if err := p.Client.DeleteDomainRecord(context.TODO(), change.Domain.ID, change.DomainRecord.ID); err != nil {
log.WithFields(logFields).Errorf( log.WithFields(logFields).Errorf(
"Failed to Delete record: %v", "Failed to Delete record: %v",
err, err,
) )
} }
} }
}
for _, change := range changes.Updates { for _, change := range changes.Updates {
logFields := log.Fields{ logFields := log.Fields{
@ -233,15 +229,13 @@ func (p *LinodeProvider) submitChanges(changes LinodeChanges) error {
if p.DryRun { if p.DryRun {
log.WithFields(logFields).Info("Would update record.") log.WithFields(logFields).Info("Would update record.")
} else { } else if _, err := p.Client.UpdateDomainRecord(context.TODO(), change.Domain.ID, change.DomainRecord.ID, change.Options); err != nil {
if _, err := p.Client.UpdateDomainRecord(context.TODO(), change.Domain.ID, change.DomainRecord.ID, change.Options); err != nil {
log.WithFields(logFields).Errorf( log.WithFields(logFields).Errorf(
"Failed to Update record: %v", "Failed to Update record: %v",
err, err,
) )
} }
} }
}
return nil return nil
} }

View File

@ -624,7 +624,7 @@ func TestMutableMockOCIDNSClient(t *testing.T) {
}) })
require.NoError(t, err) require.NoError(t, err)
// GetZoneRecords and check we're back in the origional state // GetZoneRecords and check we're back in the original state
recordsResponse, err = client.GetZoneRecords(context.Background(), dns.GetZoneRecordsRequest{ recordsResponse, err = client.GetZoneRecords(context.Background(), dns.GetZoneRecordsRequest{
ZoneNameOrId: zones[0].Id, ZoneNameOrId: zones[0].Id,
}) })

View File

@ -42,7 +42,7 @@ type pdnsChangeType string
const ( const (
apiBase = "/api/v1" apiBase = "/api/v1"
// Unless we use something like pdnsproxy (discontinued upsteam), this value will _always_ be localhost // Unless we use something like pdnsproxy (discontinued upstream), this value will _always_ be localhost
defaultServerID = "localhost" defaultServerID = "localhost"
defaultTTL = 300 defaultTTL = 300
@ -455,7 +455,7 @@ func (p *PDNSProvider) ApplyChanges(ctx context.Context, changes *plan.Changes)
// valid call and a no-op, but we might as well not make the call to // valid call and a no-op, but we might as well not make the call to
// prevent unnecessary logging // prevent unnecessary logging
if len(changes.Create) > 0 { if len(changes.Create) > 0 {
// "Replacing" non-existant records creates them // "Replacing" non-existent records creates them
err := p.mutateRecords(changes.Create, PdnsReplace) err := p.mutateRecords(changes.Create, PdnsReplace)
if err != nil { if err != nil {
return err return err

View File

@ -536,7 +536,7 @@ func (c *PDNSAPIClientStub) PatchZone(zoneID string, zoneStruct pgo.Zone) (*http
/******************************************************************************/ /******************************************************************************/
// API that returns a zones with no records // API that returns a zones with no records
type PDNSAPIClientStubEmptyZones struct { type PDNSAPIClientStubEmptyZones struct {
// Keep track of all zones we recieve via PatchZone // Keep track of all zones we receive via PatchZone
patchedZones []pgo.Zone patchedZones []pgo.Zone
} }

View File

@ -129,11 +129,9 @@ func (p *RcodeZeroProvider) Records() ([]*endpoint.Endpoint, error) {
} }
} }
} else { } else if !r.Records[0].Disabled {
if !r.Records[0].Disabled {
endpoints = append(endpoints, endpoint.NewEndpointWithTTL(r.Name, r.Type, endpoint.TTL(r.TTL), r.Records[0].Content)) endpoints = append(endpoints, endpoint.NewEndpointWithTTL(r.Name, r.Type, endpoint.TTL(r.TTL), r.Records[0].Content))
} }
}
} }
} }

View File

@ -65,7 +65,7 @@ func (c fakeEtcdv3Client) List(rootDomain string) ([]RDNSRecord, error) {
k := &mvccpb.KeyValue{ k := &mvccpb.KeyValue{
Key: []byte(v.Key), Key: []byte(v.Key),
Value: []byte(b), Value: b,
} }
r.Kvs = append(r.Kvs, k) r.Kvs = append(r.Kvs, k)

View File

@ -97,7 +97,7 @@ func (p *vinyldnsProvider) Records() (endpoints []*endpoint.Endpoint, _ error) {
} }
for _, r := range records { for _, r := range records {
if supportedRecordType(string(r.Type)) { if supportedRecordType(r.Type) {
recordsCount := len(r.Records) recordsCount := len(r.Records)
log.Debugf(fmt.Sprintf("%s.%s.%d.%s", r.Name, r.Type, recordsCount, zone.Name)) log.Debugf(fmt.Sprintf("%s.%s.%d.%s", r.Name, r.Type, recordsCount, zone.Name))
@ -115,7 +115,7 @@ func (p *vinyldnsProvider) Records() (endpoints []*endpoint.Endpoint, _ error) {
} }
} }
endpoints = append(endpoints, endpoint.NewEndpointWithTTL(r.Name+"."+zone.Name, string(r.Type), endpoint.TTL(r.TTL), targets...)) endpoints = append(endpoints, endpoint.NewEndpointWithTTL(r.Name+"."+zone.Name, r.Type, endpoint.TTL(r.TTL), targets...))
} }
} }
} }

View File

@ -60,7 +60,7 @@ func (cs *connectorSource) Endpoints() ([]*endpoint.Endpoint, error) {
return nil, err return nil, err
} }
log.Debugf("Recieved endpoints: %#v", endpoints) log.Debugf("Received endpoints: %#v", endpoints)
return endpoints, nil return endpoints, nil
} }

View File

@ -171,8 +171,8 @@ func (ns *nodeSource) Endpoints() ([]*endpoint.Endpoint, error) {
// basically what k8s.io/kubernetes/pkg/util/node.GetPreferredNodeAddress does // basically what k8s.io/kubernetes/pkg/util/node.GetPreferredNodeAddress does
func (ns *nodeSource) nodeAddresses(node *v1.Node) ([]string, error) { func (ns *nodeSource) nodeAddresses(node *v1.Node) ([]string, error) {
addresses := map[v1.NodeAddressType][]string{ addresses := map[v1.NodeAddressType][]string{
v1.NodeExternalIP: []string{}, v1.NodeExternalIP: {},
v1.NodeInternalIP: []string{}, v1.NodeInternalIP: {},
} }
for _, addr := range node.Status.Addresses { for _, addr := range node.Status.Addresses {