2014-06-17 23:23:52 +00:00
|
|
|
/*
|
|
|
|
Copyright 2014 Google Inc. 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.
|
|
|
|
*/
|
|
|
|
|
2014-06-30 19:00:14 +00:00
|
|
|
package tools
|
2014-06-17 23:23:52 +00:00
|
|
|
|
|
|
|
import (
|
|
|
|
"encoding/json"
|
|
|
|
"fmt"
|
|
|
|
"reflect"
|
|
|
|
|
2014-06-30 19:00:14 +00:00
|
|
|
"github.com/GoogleCloudPlatform/kubernetes/pkg/api"
|
2014-07-20 06:26:26 +00:00
|
|
|
"github.com/GoogleCloudPlatform/kubernetes/pkg/util"
|
|
|
|
"github.com/GoogleCloudPlatform/kubernetes/pkg/watch"
|
2014-06-17 23:23:52 +00:00
|
|
|
"github.com/coreos/go-etcd/etcd"
|
2014-07-20 06:26:26 +00:00
|
|
|
"github.com/golang/glog"
|
2014-06-17 23:23:52 +00:00
|
|
|
)
|
|
|
|
|
2014-07-15 11:48:06 +00:00
|
|
|
const (
|
|
|
|
EtcdErrorCodeNotFound = 100
|
|
|
|
EtcdErrorCodeValueRequired = 200
|
|
|
|
)
|
|
|
|
|
|
|
|
var (
|
|
|
|
EtcdErrorNotFound = &etcd.EtcdError{ErrorCode: EtcdErrorCodeNotFound}
|
|
|
|
EtcdErrorValueRequired = &etcd.EtcdError{ErrorCode: EtcdErrorCodeValueRequired}
|
|
|
|
)
|
|
|
|
|
2014-06-27 03:24:10 +00:00
|
|
|
// EtcdClient is an injectable interface for testing.
|
|
|
|
type EtcdClient interface {
|
|
|
|
AddChild(key, data string, ttl uint64) (*etcd.Response, error)
|
|
|
|
Get(key string, sort, recursive bool) (*etcd.Response, error)
|
|
|
|
Set(key, value string, ttl uint64) (*etcd.Response, error)
|
|
|
|
Create(key, value string, ttl uint64) (*etcd.Response, error)
|
|
|
|
CompareAndSwap(key, value string, ttl uint64, prevValue string, prevIndex uint64) (*etcd.Response, error)
|
|
|
|
Delete(key string, recursive bool) (*etcd.Response, error)
|
|
|
|
// I'd like to use directional channels here (e.g. <-chan) but this interface mimics
|
|
|
|
// the etcd client interface which doesn't, and it doesn't seem worth it to wrap the api.
|
|
|
|
Watch(prefix string, waitIndex uint64, recursive bool, receiver chan *etcd.Response, stop chan bool) (*etcd.Response, error)
|
|
|
|
}
|
|
|
|
|
2014-06-17 23:23:52 +00:00
|
|
|
// Interface exposing only the etcd operations needed by EtcdHelper.
|
|
|
|
type EtcdGetSet interface {
|
|
|
|
Get(key string, sort, recursive bool) (*etcd.Response, error)
|
|
|
|
Set(key, value string, ttl uint64) (*etcd.Response, error)
|
2014-06-27 03:24:10 +00:00
|
|
|
CompareAndSwap(key, value string, ttl uint64, prevValue string, prevIndex uint64) (*etcd.Response, error)
|
2014-07-20 06:26:26 +00:00
|
|
|
Watch(prefix string, waitIndex uint64, recursive bool, receiver chan *etcd.Response, stop chan bool) (*etcd.Response, error)
|
2014-06-17 23:23:52 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// EtcdHelper offers common object marshalling/unmarshalling operations on an etcd client.
|
|
|
|
type EtcdHelper struct {
|
|
|
|
Client EtcdGetSet
|
|
|
|
}
|
|
|
|
|
|
|
|
// Returns true iff err is an etcd not found error.
|
|
|
|
func IsEtcdNotFound(err error) bool {
|
2014-06-27 03:24:10 +00:00
|
|
|
return isEtcdErrorNum(err, 100)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Returns true iff err is an etcd write conflict.
|
|
|
|
func IsEtcdConflict(err error) bool {
|
|
|
|
return isEtcdErrorNum(err, 101)
|
|
|
|
}
|
|
|
|
|
2014-07-15 14:52:39 +00:00
|
|
|
// IsEtcdWatchStoppedByUser returns true iff err is a client triggered stop.
|
|
|
|
func IsEtcdWatchStoppedByUser(err error) bool {
|
|
|
|
return etcd.ErrWatchStoppedByUser == err
|
|
|
|
}
|
|
|
|
|
2014-06-27 03:24:10 +00:00
|
|
|
// Returns true iff err is an etcd error, whose errorCode matches errorCode
|
|
|
|
func isEtcdErrorNum(err error, errorCode int) bool {
|
2014-07-16 05:27:15 +00:00
|
|
|
etcdError, ok := err.(*etcd.EtcdError)
|
|
|
|
return ok && etcdError != nil && etcdError.ErrorCode == errorCode
|
2014-06-17 23:23:52 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func (h *EtcdHelper) listEtcdNode(key string) ([]*etcd.Node, error) {
|
|
|
|
result, err := h.Client.Get(key, false, true)
|
|
|
|
if err != nil {
|
|
|
|
nodes := make([]*etcd.Node, 0)
|
|
|
|
if IsEtcdNotFound(err) {
|
|
|
|
return nodes, nil
|
|
|
|
} else {
|
|
|
|
return nodes, err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return result.Node.Nodes, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Extract a go object per etcd node into a slice.
|
|
|
|
func (h *EtcdHelper) ExtractList(key string, slicePtr interface{}) error {
|
|
|
|
nodes, err := h.listEtcdNode(key)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
pv := reflect.ValueOf(slicePtr)
|
|
|
|
if pv.Type().Kind() != reflect.Ptr || pv.Type().Elem().Kind() != reflect.Slice {
|
|
|
|
// This should not happen at runtime.
|
|
|
|
panic("need ptr to slice")
|
|
|
|
}
|
|
|
|
v := pv.Elem()
|
|
|
|
for _, node := range nodes {
|
|
|
|
obj := reflect.New(v.Type().Elem())
|
|
|
|
err = json.Unmarshal([]byte(node.Value), obj.Interface())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
v.Set(reflect.Append(v, obj.Elem()))
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Unmarshals json found at key into objPtr. On a not found error, will either return
|
|
|
|
// a zero object of the requested type, or an error, depending on ignoreNotFound. Treats
|
|
|
|
// empty responses and nil response nodes exactly like a not found error.
|
2014-06-27 17:55:05 +00:00
|
|
|
func (h *EtcdHelper) ExtractObj(key string, objPtr interface{}, ignoreNotFound bool) error {
|
2014-07-02 20:51:27 +00:00
|
|
|
_, _, err := h.bodyAndExtractObj(key, objPtr, ignoreNotFound)
|
|
|
|
return err
|
2014-06-27 19:54:45 +00:00
|
|
|
}
|
2014-06-27 17:55:05 +00:00
|
|
|
|
|
|
|
func (h *EtcdHelper) bodyAndExtractObj(key string, objPtr interface{}, ignoreNotFound bool) (body string, modifiedIndex uint64, err error) {
|
2014-06-17 23:23:52 +00:00
|
|
|
response, err := h.Client.Get(key, false, false)
|
2014-06-18 20:10:19 +00:00
|
|
|
|
|
|
|
if err != nil && !IsEtcdNotFound(err) {
|
2014-06-27 17:55:05 +00:00
|
|
|
return "", 0, err
|
2014-06-17 23:23:52 +00:00
|
|
|
}
|
2014-06-18 20:10:19 +00:00
|
|
|
if err != nil || response.Node == nil || len(response.Node.Value) == 0 {
|
2014-06-17 23:23:52 +00:00
|
|
|
if ignoreNotFound {
|
2014-06-18 20:10:19 +00:00
|
|
|
pv := reflect.ValueOf(objPtr)
|
|
|
|
pv.Elem().Set(reflect.Zero(pv.Type().Elem()))
|
2014-06-27 17:55:05 +00:00
|
|
|
return "", 0, nil
|
2014-06-18 20:10:19 +00:00
|
|
|
} else if err != nil {
|
2014-06-27 17:55:05 +00:00
|
|
|
return "", 0, err
|
2014-06-17 23:23:52 +00:00
|
|
|
}
|
2014-06-27 17:55:05 +00:00
|
|
|
return "", 0, fmt.Errorf("key '%v' found no nodes field: %#v", key, response)
|
2014-06-27 03:24:10 +00:00
|
|
|
}
|
2014-06-27 17:55:05 +00:00
|
|
|
body = response.Node.Value
|
2014-07-02 20:51:27 +00:00
|
|
|
err = json.Unmarshal([]byte(body), objPtr)
|
|
|
|
if jsonBase, err := api.FindJSONBase(objPtr); err == nil {
|
|
|
|
jsonBase.ResourceVersion = response.Node.ModifiedIndex
|
|
|
|
// Note that err shadows the err returned below, so we won't
|
|
|
|
// return an error just because we failed to find a JSONBase.
|
|
|
|
// This is intentional.
|
|
|
|
}
|
|
|
|
return body, response.Node.ModifiedIndex, err
|
2014-06-27 03:24:10 +00:00
|
|
|
}
|
|
|
|
|
2014-07-02 20:51:27 +00:00
|
|
|
// SetObj marshals obj via json, and stores under key. Will do an
|
|
|
|
// atomic update if obj's ResourceVersion field is set.
|
2014-06-27 17:55:05 +00:00
|
|
|
func (h *EtcdHelper) SetObj(key string, obj interface{}) error {
|
2014-06-27 03:24:10 +00:00
|
|
|
data, err := json.Marshal(obj)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
2014-06-17 23:23:52 +00:00
|
|
|
}
|
2014-07-02 20:51:27 +00:00
|
|
|
if jsonBase, err := api.FindJSONBaseRO(obj); err == nil && jsonBase.ResourceVersion != 0 {
|
2014-06-30 19:00:14 +00:00
|
|
|
_, err = h.Client.CompareAndSwap(key, string(data), 0, "", jsonBase.ResourceVersion)
|
2014-07-02 20:51:27 +00:00
|
|
|
return err // err is shadowed!
|
2014-06-30 19:00:14 +00:00
|
|
|
}
|
2014-07-02 20:51:27 +00:00
|
|
|
|
|
|
|
// TODO: when client supports atomic creation, integrate this with the above.
|
|
|
|
_, err = h.Client.Set(key, string(data), 0)
|
2014-06-27 03:24:10 +00:00
|
|
|
return err
|
2014-06-17 23:23:52 +00:00
|
|
|
}
|
|
|
|
|
2014-06-27 17:55:05 +00:00
|
|
|
// Pass an EtcdUpdateFunc to EtcdHelper.AtomicUpdate to make an atomic etcd update.
|
|
|
|
// See the comment for AtomicUpdate for more detail.
|
2014-06-27 22:02:06 +00:00
|
|
|
type EtcdUpdateFunc func(input interface{}) (output interface{}, err error)
|
2014-06-27 17:55:05 +00:00
|
|
|
|
|
|
|
// AtomicUpdate generalizes the pattern that allows for making atomic updates to etcd objects.
|
|
|
|
// Note, tryUpdate may be called more than once.
|
|
|
|
//
|
|
|
|
// Example:
|
|
|
|
//
|
|
|
|
// h := &util.EtcdHelper{client}
|
2014-06-27 22:02:06 +00:00
|
|
|
// err := h.AtomicUpdate("myKey", &MyType{}, func(input interface{}) (interface{}, error) {
|
2014-06-27 17:55:05 +00:00
|
|
|
// // Before this function is called, currentObj has been reset to etcd's current
|
|
|
|
// // contents for "myKey".
|
|
|
|
//
|
2014-06-27 22:02:06 +00:00
|
|
|
// cur := input.(*MyType) // Gauranteed to work.
|
|
|
|
//
|
2014-06-27 17:55:05 +00:00
|
|
|
// // Make a *modification*.
|
2014-06-27 22:02:06 +00:00
|
|
|
// cur.Counter++
|
2014-06-27 17:55:05 +00:00
|
|
|
//
|
|
|
|
// // Return the modified object. Return an error to stop iterating.
|
2014-06-27 22:02:06 +00:00
|
|
|
// return cur, nil
|
2014-06-27 17:55:05 +00:00
|
|
|
// })
|
|
|
|
//
|
2014-06-27 22:02:06 +00:00
|
|
|
func (h *EtcdHelper) AtomicUpdate(key string, ptrToType interface{}, tryUpdate EtcdUpdateFunc) error {
|
|
|
|
pt := reflect.TypeOf(ptrToType)
|
|
|
|
if pt.Kind() != reflect.Ptr {
|
|
|
|
// Panic is appropriate, because this is a programming error.
|
|
|
|
panic("need ptr to type")
|
|
|
|
}
|
2014-06-27 17:55:05 +00:00
|
|
|
for {
|
2014-06-27 22:02:06 +00:00
|
|
|
obj := reflect.New(pt.Elem()).Interface()
|
|
|
|
origBody, index, err := h.bodyAndExtractObj(key, obj, true)
|
2014-06-27 17:55:05 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2014-06-27 22:02:06 +00:00
|
|
|
ret, err := tryUpdate(obj)
|
2014-06-27 17:55:05 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2014-06-27 19:54:45 +00:00
|
|
|
// First time this key has been used, just set.
|
2014-06-27 22:02:06 +00:00
|
|
|
// TODO: This is racy. Fix when our client supports prevExist. See:
|
|
|
|
// https://github.com/coreos/etcd/blob/master/Documentation/api.md#atomic-compare-and-swap
|
2014-06-27 19:54:45 +00:00
|
|
|
if index == 0 {
|
2014-06-27 22:02:06 +00:00
|
|
|
return h.SetObj(key, ret)
|
2014-06-27 19:54:45 +00:00
|
|
|
}
|
|
|
|
|
2014-06-27 17:55:05 +00:00
|
|
|
data, err := json.Marshal(ret)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
_, err = h.Client.CompareAndSwap(key, string(data), 0, origBody, index)
|
2014-06-27 19:54:45 +00:00
|
|
|
if IsEtcdConflict(err) {
|
|
|
|
continue
|
|
|
|
}
|
2014-06-17 23:23:52 +00:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
2014-07-20 06:26:26 +00:00
|
|
|
|
|
|
|
// FilterFunc is a predicate which takes an API object and returns true
|
|
|
|
// iff the object should remain in the set.
|
|
|
|
type FilterFunc func(obj interface{}) bool
|
|
|
|
|
|
|
|
// Everything is a FilterFunc which accepts all objects.
|
|
|
|
func Everything(interface{}) bool {
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
|
|
|
|
// WatchList begins watching the specified key's items. Items are decoded into
|
|
|
|
// API objects, and any items passing 'filter' are sent down the returned
|
|
|
|
// watch.Interface.
|
|
|
|
func (h *EtcdHelper) WatchList(key string, filter FilterFunc) (watch.Interface, error) {
|
|
|
|
w := newEtcdWatcher(true, filter)
|
|
|
|
go w.etcdWatch(h.Client, key)
|
|
|
|
return w, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Watch begins watching the specified key. Events are decoded into
|
|
|
|
// API objects and sent down the returned watch.Interface.
|
|
|
|
func (h *EtcdHelper) Watch(key string) (watch.Interface, error) {
|
|
|
|
w := newEtcdWatcher(false, nil)
|
|
|
|
go w.etcdWatch(h.Client, key)
|
|
|
|
return w, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// etcdWatcher converts a native etcd watch to a watch.Interface.
|
|
|
|
type etcdWatcher struct {
|
|
|
|
list bool // If we're doing a recursive watch, should be true.
|
|
|
|
filter FilterFunc
|
|
|
|
|
|
|
|
etcdIncoming chan *etcd.Response
|
|
|
|
etcdStop chan bool
|
|
|
|
|
|
|
|
outgoing chan watch.Event
|
|
|
|
userStop chan struct{}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Returns a new etcdWatcher; if list is true, watch sub-nodes.
|
|
|
|
func newEtcdWatcher(list bool, filter FilterFunc) *etcdWatcher {
|
|
|
|
w := &etcdWatcher{
|
|
|
|
list: list,
|
|
|
|
filter: filter,
|
|
|
|
etcdIncoming: make(chan *etcd.Response),
|
|
|
|
etcdStop: make(chan bool),
|
|
|
|
outgoing: make(chan watch.Event),
|
|
|
|
userStop: make(chan struct{}),
|
|
|
|
}
|
|
|
|
go w.translate()
|
|
|
|
return w
|
|
|
|
}
|
|
|
|
|
|
|
|
// etcdWatch calls etcd's Watch function, and handles any errors. Meant to be called
|
|
|
|
// as a goroutine.
|
|
|
|
func (w *etcdWatcher) etcdWatch(client EtcdGetSet, key string) {
|
|
|
|
defer util.HandleCrash()
|
|
|
|
_, err := client.Watch(key, 0, w.list, w.etcdIncoming, w.etcdStop)
|
|
|
|
if err == etcd.ErrWatchStoppedByUser {
|
|
|
|
// etcd doesn't close the channel in this case.
|
|
|
|
close(w.etcdIncoming)
|
|
|
|
} else {
|
|
|
|
glog.Errorf("etcd.Watch stopped unexpectedly: %v (%#v)", err, err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Pull stuff from etcd, convert, and push out the outgoing channel. Meant to be
|
|
|
|
// called as a goroutine.
|
|
|
|
func (w *etcdWatcher) translate() {
|
|
|
|
defer close(w.outgoing)
|
|
|
|
defer util.HandleCrash()
|
|
|
|
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-w.userStop:
|
|
|
|
w.etcdStop <- true
|
|
|
|
return
|
|
|
|
case res, ok := <-w.etcdIncoming:
|
|
|
|
if !ok {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
w.sendResult(res)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (w *etcdWatcher) sendResult(res *etcd.Response) {
|
|
|
|
var action watch.EventType
|
|
|
|
var data []byte
|
|
|
|
var nodes etcd.Nodes
|
|
|
|
switch res.Action {
|
|
|
|
case "set":
|
|
|
|
if res.Node == nil {
|
|
|
|
glog.Errorf("unexpected nil node: %#v", res)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
data = []byte(res.Node.Value)
|
|
|
|
nodes = res.Node.Nodes
|
|
|
|
// TODO: Is this conditional correct?
|
|
|
|
if res.EtcdIndex > 0 {
|
|
|
|
action = watch.Modified
|
|
|
|
} else {
|
|
|
|
action = watch.Added
|
|
|
|
}
|
|
|
|
case "delete":
|
|
|
|
if res.PrevNode == nil {
|
|
|
|
glog.Errorf("unexpected nil prev node: %#v", res)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
data = []byte(res.PrevNode.Value)
|
|
|
|
nodes = res.PrevNode.Nodes
|
|
|
|
action = watch.Deleted
|
|
|
|
}
|
|
|
|
|
|
|
|
// If listing, we're interested in sub-nodes.
|
|
|
|
if w.list {
|
|
|
|
for _, n := range nodes {
|
|
|
|
obj, err := api.Decode([]byte(n.Value))
|
|
|
|
if err != nil {
|
|
|
|
glog.Errorf("failure to decode api object: %#v", res)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
if w.filter != nil && !w.filter(obj) {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
w.outgoing <- watch.Event{
|
|
|
|
Type: action,
|
|
|
|
Object: obj,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
obj, err := api.Decode(data)
|
|
|
|
if err != nil {
|
|
|
|
glog.Errorf("failure to decode api object: %#v", res)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
w.outgoing <- watch.Event{
|
|
|
|
Type: action,
|
|
|
|
Object: obj,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// ResultChannel implements watch.Interface.
|
|
|
|
func (w *etcdWatcher) ResultChan() <-chan watch.Event {
|
|
|
|
return w.outgoing
|
|
|
|
}
|
|
|
|
|
|
|
|
// Stop implements watch.Interface.
|
|
|
|
func (w *etcdWatcher) Stop() {
|
|
|
|
close(w.userStop)
|
|
|
|
}
|