etcd/store/store.go

600 lines
15 KiB
Go
Raw Normal View History

2013-10-07 20:44:51 +04:00
/*
Copyright 2013 CoreOS Inc.
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.
*/
2013-09-29 03:26:19 +04:00
package store
2013-09-03 22:30:42 +04:00
import (
2013-09-14 01:10:40 +04:00
"encoding/json"
2013-09-05 23:38:22 +04:00
"fmt"
"path"
2013-09-09 05:14:31 +04:00
"sort"
"strconv"
2013-09-03 22:30:42 +04:00
"strings"
2013-09-29 03:58:57 +04:00
"sync"
2013-09-03 22:30:42 +04:00
"time"
2013-09-29 03:26:19 +04:00
etcdErr "github.com/coreos/etcd/error"
2013-09-03 22:30:42 +04:00
)
2013-10-27 22:47:00 +04:00
// The default version to set when the store is first initialized.
const defaultVersion = 2
2013-11-06 02:57:53 +04:00
var minExpireTime time.Time
func init() {
minExpireTime, _ = time.Parse(time.RFC3339, "2000-01-01T00:00:00Z")
}
2013-10-14 21:12:30 +04:00
type Store interface {
2013-10-27 22:47:00 +04:00
Version() int
CommandFactory() CommandFactory
Index() uint64
2013-12-06 02:10:37 +04:00
Get(nodePath string, recursive, sorted bool) (*Event, error)
2013-12-06 02:10:37 +04:00
Set(nodePath string, dir bool, value string, expireTime time.Time) (*Event, error)
Update(nodePath string, newValue string, expireTime time.Time) (*Event, error)
2013-12-06 02:10:37 +04:00
Create(nodePath string, dir bool, value string, unique bool,
expireTime time.Time) (*Event, error)
2013-10-15 09:22:23 +04:00
CompareAndSwap(nodePath string, prevValue string, prevIndex uint64,
value string, expireTime time.Time) (*Event, error)
2013-12-06 02:10:37 +04:00
Delete(nodePath string, recursive, dir bool) (*Event, error)
Watch(prefix string, recursive bool, sinceIndex uint64) (<-chan *Event, error)
2013-12-06 02:10:37 +04:00
2013-10-14 21:12:30 +04:00
Save() ([]byte, error)
Recovery(state []byte) error
2013-12-06 02:10:37 +04:00
2013-10-31 02:14:34 +04:00
TotalTransactions() uint64
2013-10-14 21:12:30 +04:00
JsonStats() []byte
DeleteExpiredKeys(cutoff time.Time)
2013-10-14 21:12:30 +04:00
}
type store struct {
Root *node
2013-10-31 04:36:15 +04:00
WatcherHub *watcherHub
CurrentIndex uint64
2013-10-31 04:36:15 +04:00
Stats *Stats
CurrentVersion int
2013-11-05 09:51:14 +04:00
ttlKeyHeap *ttlKeyHeap // need to recovery manually
2013-10-31 04:36:15 +04:00
worldLock sync.RWMutex // stop the world lock
2013-09-03 22:30:42 +04:00
}
2013-10-14 21:12:30 +04:00
func New() Store {
return newStore()
}
func newStore() *store {
s := new(store)
2013-10-27 22:47:00 +04:00
s.CurrentVersion = defaultVersion
s.Root = newDir(s, "/", s.CurrentIndex, nil, "", Permanent)
2013-09-29 03:26:19 +04:00
s.Stats = newStats()
s.WatcherHub = newWatchHub(1000)
2013-11-05 09:51:14 +04:00
s.ttlKeyHeap = newTtlKeyHeap()
2013-09-29 03:26:19 +04:00
return s
2013-09-03 22:30:42 +04:00
}
2013-10-27 22:47:00 +04:00
// Version retrieves current version of the store.
func (s *store) Version() int {
return s.CurrentVersion
}
// Retrieves current of the store
func (s *store) Index() uint64 {
return s.CurrentIndex
}
2013-10-27 22:47:00 +04:00
// CommandFactory retrieves the command factory for the current version of the store.
func (s *store) CommandFactory() CommandFactory {
return GetCommandFactory(s.Version())
}
// Get function returns a get event.
// If recursive is true, it will return all the content under the node path.
// If sorted is true, it will sort the content by keys.
func (s *store) Get(nodePath string, recursive, sorted bool) (*Event, error) {
2013-09-29 03:58:57 +04:00
s.worldLock.RLock()
defer s.worldLock.RUnlock()
2013-09-14 23:13:33 +04:00
nodePath = path.Clean(path.Join("/", nodePath))
n, err := s.internalGet(nodePath)
2013-09-03 22:30:42 +04:00
2013-09-04 05:27:46 +04:00
if err != nil {
2013-09-29 03:26:19 +04:00
s.Stats.Inc(GetFail)
2013-09-04 05:27:46 +04:00
return nil, err
}
2013-09-03 22:30:42 +04:00
2013-11-28 08:04:52 +04:00
e := newEvent(Get, nodePath, n.ModifiedIndex, n.CreatedIndex)
eNode := e.Node
2013-09-03 22:30:42 +04:00
if n.IsDir() { // node is a directory
2013-11-28 08:04:52 +04:00
eNode.Dir = true
2013-09-03 22:30:42 +04:00
2013-09-06 07:10:41 +04:00
children, _ := n.List()
eNode.Nodes = make(NodeExterns, len(children))
2013-09-06 07:10:41 +04:00
// we do not use the index in the children slice directly
// we need to skip the hidden one
2013-09-04 05:27:46 +04:00
i := 0
2013-09-03 22:30:42 +04:00
2013-09-06 07:10:41 +04:00
for _, child := range children {
if child.IsHidden() { // get will not return hidden nodes
2013-09-04 06:35:25 +04:00
continue
}
2013-11-28 08:04:52 +04:00
eNode.Nodes[i] = child.Repr(recursive, sorted)
2013-09-04 05:27:46 +04:00
i++
}
2013-09-04 07:10:33 +04:00
// eliminate hidden nodes
2013-11-28 08:04:52 +04:00
eNode.Nodes = eNode.Nodes[:i]
if sorted {
2013-11-28 08:04:52 +04:00
sort.Sort(eNode.Nodes)
2013-09-09 05:14:31 +04:00
}
2013-10-09 08:49:10 +04:00
} else { // node is a file
2013-11-28 08:04:52 +04:00
eNode.Value, _ = n.Read()
2013-09-03 22:30:42 +04:00
}
2013-11-28 08:04:52 +04:00
eNode.Expiration, eNode.TTL = n.ExpirationAndTTL()
2013-09-14 23:13:33 +04:00
2013-09-29 03:26:19 +04:00
s.Stats.Inc(GetSuccess)
2013-09-04 05:27:46 +04:00
return e, nil
2013-09-03 22:30:42 +04:00
}
// Create function creates the node at nodePath. Create will help to create intermediate directories with no ttl.
// If the node has already existed, create will fail.
// If any node on the path is a file, create will fail.
2013-12-06 02:10:37 +04:00
func (s *store) Create(nodePath string, dir bool, value string, unique bool, expireTime time.Time) (*Event, error) {
2013-10-01 10:18:52 +04:00
s.worldLock.Lock()
defer s.worldLock.Unlock()
2013-12-06 02:10:37 +04:00
e, err := s.internalCreate(nodePath, dir, value, unique, false, expireTime, Create)
2013-10-16 10:18:03 +04:00
if err == nil {
s.Stats.Inc(CreateSuccess)
} else {
s.Stats.Inc(CreateFail)
}
return e, err
2013-10-15 10:04:21 +04:00
}
// Set function creates or replace the node at nodePath.
2013-12-06 02:10:37 +04:00
func (s *store) Set(nodePath string, dir bool, value string, expireTime time.Time) (*Event, error) {
2013-10-15 10:04:21 +04:00
s.worldLock.Lock()
defer s.worldLock.Unlock()
2013-12-06 02:10:37 +04:00
e, err := s.internalCreate(nodePath, dir, value, false, true, expireTime, Set)
2013-10-16 10:18:03 +04:00
if err == nil {
s.Stats.Inc(SetSuccess)
} else {
s.Stats.Inc(SetFail)
}
return e, err
2013-09-03 22:30:42 +04:00
}
2013-10-15 09:22:23 +04:00
func (s *store) CompareAndSwap(nodePath string, prevValue string, prevIndex uint64,
value string, expireTime time.Time) (*Event, error) {
2013-10-06 22:23:52 +04:00
nodePath = path.Clean(path.Join("/", nodePath))
2013-12-02 03:01:24 +04:00
// we do not allow the user to change "/"
if nodePath == "/" {
return nil, etcdErr.NewError(etcdErr.EcodeRootROnly, "/", s.CurrentIndex)
}
2013-10-06 22:23:52 +04:00
2013-10-01 10:18:52 +04:00
s.worldLock.Lock()
defer s.worldLock.Unlock()
2013-09-29 03:58:57 +04:00
n, err := s.internalGet(nodePath)
2013-09-03 22:30:42 +04:00
2013-09-05 23:38:22 +04:00
if err != nil {
s.Stats.Inc(CompareAndSwapFail)
2013-09-05 23:38:22 +04:00
return nil, err
}
2013-09-03 22:30:42 +04:00
if n.IsDir() { // can only test and set file
s.Stats.Inc(CompareAndSwapFail)
return nil, etcdErr.NewError(etcdErr.EcodeNotFile, nodePath, s.CurrentIndex)
2013-09-05 23:38:22 +04:00
}
2013-10-14 23:57:35 +04:00
// If both of the prevValue and prevIndex are given, we will test both of them.
// Command will be executed, only if both of the tests are successful.
if (prevValue == "" || n.Value == prevValue) && (prevIndex == 0 || n.ModifiedIndex == prevIndex) {
// update etcd index
s.CurrentIndex++
2013-11-28 08:04:52 +04:00
e := newEvent(CompareAndSwap, nodePath, s.CurrentIndex, n.CreatedIndex)
eNode := e.Node
eNode.PrevValue = n.Value
2013-10-09 09:10:18 +04:00
2013-09-05 23:38:22 +04:00
// if test succeed, write the value
n.Write(value, s.CurrentIndex)
2013-10-14 21:12:30 +04:00
n.UpdateTTL(expireTime)
2013-11-28 08:04:52 +04:00
eNode.Value = value
eNode.Expiration, eNode.TTL = n.ExpirationAndTTL()
2013-10-06 22:23:52 +04:00
2013-09-29 03:26:19 +04:00
s.WatcherHub.notify(e)
s.Stats.Inc(CompareAndSwapSuccess)
2013-09-05 23:38:22 +04:00
return e, nil
}
cause := fmt.Sprintf("[%v != %v] [%v != %v]", prevValue, n.Value, prevIndex, n.ModifiedIndex)
s.Stats.Inc(CompareAndSwapFail)
return nil, etcdErr.NewError(etcdErr.EcodeTestFailed, cause, s.CurrentIndex)
2013-09-03 22:30:42 +04:00
}
// Delete function deletes the node at the given path.
// If the node is a directory, recursive must be true to delete it.
2013-12-06 02:10:37 +04:00
func (s *store) Delete(nodePath string, dir, recursive bool) (*Event, error) {
2013-10-06 22:23:52 +04:00
nodePath = path.Clean(path.Join("/", nodePath))
2013-12-02 03:01:24 +04:00
// we do not allow the user to change "/"
if nodePath == "/" {
return nil, etcdErr.NewError(etcdErr.EcodeRootROnly, "/", s.CurrentIndex)
}
2013-10-06 22:23:52 +04:00
2013-10-01 10:18:52 +04:00
s.worldLock.Lock()
defer s.worldLock.Unlock()
2013-09-29 03:58:57 +04:00
2013-12-06 05:46:52 +04:00
// recursive implies dir
if recursive == true {
dir = true
}
2013-11-10 08:49:19 +04:00
nextIndex := s.CurrentIndex + 1
n, err := s.internalGet(nodePath)
2013-09-03 22:30:42 +04:00
if err != nil { // if the node does not exist, return error
2013-09-29 03:26:19 +04:00
s.Stats.Inc(DeleteFail)
2013-09-04 06:35:25 +04:00
return nil, err
}
2013-11-28 08:04:52 +04:00
e := newEvent(Delete, nodePath, nextIndex, n.CreatedIndex)
eNode := e.Node
2013-09-04 06:35:25 +04:00
if n.IsDir() {
2013-11-28 08:04:52 +04:00
eNode.Dir = true
2013-09-04 06:35:25 +04:00
} else {
eNode.PrevValue = n.Value
2013-09-04 06:35:25 +04:00
}
callback := func(path string) { // notify function
2013-10-08 09:17:58 +04:00
// notify the watchers with delted set true
s.WatcherHub.notifyWatchers(e, path, true)
2013-09-07 09:05:11 +04:00
}
2013-12-06 02:10:37 +04:00
err = n.Remove(dir, recursive, callback)
2013-09-07 09:05:11 +04:00
if err != nil {
2013-09-29 03:26:19 +04:00
s.Stats.Inc(DeleteFail)
2013-09-07 09:05:11 +04:00
return nil, err
}
// update etcd index
s.CurrentIndex++
2013-09-29 03:26:19 +04:00
s.WatcherHub.notify(e)
s.Stats.Inc(DeleteSuccess)
2013-09-07 09:05:11 +04:00
2013-09-04 06:35:25 +04:00
return e, nil
2013-09-03 22:30:42 +04:00
}
func (s *store) Watch(key string, recursive bool, sinceIndex uint64) (<-chan *Event, error) {
key = path.Clean(path.Join("/", key))
2013-10-06 22:23:52 +04:00
nextIndex := s.CurrentIndex + 1
2013-09-29 03:58:57 +04:00
s.worldLock.RLock()
defer s.worldLock.RUnlock()
2013-10-06 22:23:52 +04:00
var c <-chan *Event
var err *etcdErr.Error
2013-09-14 23:13:33 +04:00
if sinceIndex == 0 {
c, err = s.WatcherHub.watch(key, recursive, nextIndex)
2013-10-06 22:23:52 +04:00
} else {
c, err = s.WatcherHub.watch(key, recursive, sinceIndex)
2013-09-14 23:13:33 +04:00
}
2013-10-06 22:23:52 +04:00
if err != nil {
// watchhub do not know the current Index
// we need to attach the currentIndex here
err.Index = s.CurrentIndex
return nil, err
2013-10-06 22:23:52 +04:00
}
return c, nil
2013-09-14 23:13:33 +04:00
}
// walk function walks all the nodePath and apply the walkFunc on each directory
func (s *store) walk(nodePath string, walkFunc func(prev *node, component string) (*node, *etcdErr.Error)) (*node, *etcdErr.Error) {
components := strings.Split(nodePath, "/")
2013-09-03 22:30:42 +04:00
2013-09-29 03:26:19 +04:00
curr := s.Root
2013-10-06 22:23:52 +04:00
var err *etcdErr.Error
2013-09-03 22:30:42 +04:00
for i := 1; i < len(components); i++ {
if len(components[i]) == 0 { // ignore empty string
return curr, nil
}
curr, err = walkFunc(curr, components[i])
if err != nil {
return nil, err
}
}
return curr, nil
}
2013-10-15 09:22:23 +04:00
// Update function updates the value/ttl of the node.
// If the node is a file, the value and the ttl can be updated.
// If the node is a directory, only the ttl can be updated.
func (s *store) Update(nodePath string, newValue string, expireTime time.Time) (*Event, error) {
2013-12-02 03:01:24 +04:00
nodePath = path.Clean(path.Join("/", nodePath))
// we do not allow the user to change "/"
if nodePath == "/" {
return nil, etcdErr.NewError(etcdErr.EcodeRootROnly, "/", s.CurrentIndex)
}
2013-10-15 09:22:23 +04:00
s.worldLock.Lock()
defer s.worldLock.Unlock()
currIndex, nextIndex := s.CurrentIndex, s.CurrentIndex+1
n, err := s.internalGet(nodePath)
2013-10-15 09:22:23 +04:00
if err != nil { // if the node does not exist, return error
s.Stats.Inc(UpdateFail)
return nil, err
}
2013-11-28 08:04:52 +04:00
e := newEvent(Update, nodePath, nextIndex, n.CreatedIndex)
eNode := e.Node
2013-10-15 09:22:23 +04:00
if n.IsDir() && len(newValue) != 0 {
// if the node is a directory, we cannot update value to non-empty
s.Stats.Inc(UpdateFail)
return nil, etcdErr.NewError(etcdErr.EcodeNotFile, nodePath, currIndex)
2013-10-15 09:22:23 +04:00
}
eNode.PrevValue = n.Value
n.Write(newValue, nextIndex)
eNode.Value = newValue
2013-10-15 09:22:23 +04:00
// update ttl
n.UpdateTTL(expireTime)
2013-11-28 08:04:52 +04:00
eNode.Expiration, eNode.TTL = n.ExpirationAndTTL()
2013-10-15 09:22:23 +04:00
s.WatcherHub.notify(e)
s.Stats.Inc(UpdateSuccess)
s.CurrentIndex = nextIndex
2013-10-15 09:22:23 +04:00
return e, nil
}
2013-12-06 02:10:37 +04:00
func (s *store) internalCreate(nodePath string, dir bool, value string, unique, replace bool,
expireTime time.Time, action string) (*Event, error) {
2013-10-06 22:23:52 +04:00
currIndex, nextIndex := s.CurrentIndex, s.CurrentIndex+1
if unique { // append unique item under the node path
nodePath += "/" + strconv.FormatUint(nextIndex, 10)
}
2013-10-03 09:15:12 +04:00
nodePath = path.Clean(path.Join("/", nodePath))
2013-12-02 03:01:24 +04:00
// we do not allow the user to change "/"
if nodePath == "/" {
return nil, etcdErr.NewError(etcdErr.EcodeRootROnly, "/", currIndex)
}
2013-11-06 02:57:53 +04:00
// Assume expire times that are way in the past are not valid.
// This can occur when the time is serialized to JSON and read back in.
if expireTime.Before(minExpireTime) {
expireTime = Permanent
}
2013-12-06 02:10:37 +04:00
dirName, nodeName := path.Split(nodePath)
2013-10-03 09:15:12 +04:00
// walk through the nodePath, create dirs and get the last directory node
2013-12-06 02:10:37 +04:00
d, err := s.walk(dirName, s.checkDir)
2013-10-03 09:15:12 +04:00
if err != nil {
s.Stats.Inc(SetFail)
err.Index = currIndex
2013-10-03 09:15:12 +04:00
return nil, err
}
2013-11-28 08:04:52 +04:00
e := newEvent(action, nodePath, nextIndex, nextIndex)
eNode := e.Node
2013-10-03 09:15:12 +04:00
2013-12-06 02:10:37 +04:00
n, _ := d.GetChild(nodeName)
// force will try to replace a existing file
if n != nil {
2013-10-15 10:15:31 +04:00
if replace {
2013-10-06 22:23:52 +04:00
if n.IsDir() {
return nil, etcdErr.NewError(etcdErr.EcodeNotFile, nodePath, currIndex)
2013-10-06 22:23:52 +04:00
}
2013-11-28 08:04:52 +04:00
eNode.PrevValue, _ = n.Read()
2013-10-06 22:23:52 +04:00
2013-12-06 02:10:37 +04:00
n.Remove(false, false, nil)
} else {
return nil, etcdErr.NewError(etcdErr.EcodeNodeExist, nodePath, currIndex)
2013-10-06 22:23:52 +04:00
}
}
2013-12-06 02:10:37 +04:00
if !dir { // create file
2013-11-28 08:04:52 +04:00
eNode.Value = value
2013-10-03 09:15:12 +04:00
n = newKV(s, nodePath, value, nextIndex, d, "", expireTime)
2013-10-03 09:15:12 +04:00
} else { // create directory
2013-11-28 08:04:52 +04:00
eNode.Dir = true
2013-10-03 09:15:12 +04:00
n = newDir(s, nodePath, nextIndex, d, "", expireTime)
2013-10-03 09:15:12 +04:00
}
2013-10-16 10:18:03 +04:00
// we are sure d is a directory and does not have the children with name n.Name
d.Add(n)
2013-10-03 09:15:12 +04:00
// node with TTL
2013-11-05 08:56:41 +04:00
if !n.IsPermanent() {
2013-11-05 09:51:14 +04:00
s.ttlKeyHeap.push(n)
2013-11-05 09:22:22 +04:00
2013-11-28 08:04:52 +04:00
eNode.Expiration, eNode.TTL = n.ExpirationAndTTL()
2013-10-03 09:15:12 +04:00
}
s.CurrentIndex = nextIndex
2013-10-03 09:15:12 +04:00
s.WatcherHub.notify(e)
return e, nil
}
// InternalGet function get the node of the given nodePath.
func (s *store) internalGet(nodePath string) (*node, *etcdErr.Error) {
2013-09-14 23:13:33 +04:00
nodePath = path.Clean(path.Join("/", nodePath))
2013-09-04 05:27:46 +04:00
walkFunc := func(parent *node, name string) (*node, *etcdErr.Error) {
2013-09-05 23:38:22 +04:00
if !parent.IsDir() {
err := etcdErr.NewError(etcdErr.EcodeNotDir, parent.Path, s.CurrentIndex)
2013-10-06 22:23:52 +04:00
return nil, err
2013-09-05 23:38:22 +04:00
}
child, ok := parent.Children[name]
2013-09-04 05:27:46 +04:00
if ok {
return child, nil
}
return nil, etcdErr.NewError(etcdErr.EcodeKeyNotFound, path.Join(parent.Path, name), s.CurrentIndex)
2013-09-04 05:27:46 +04:00
}
2013-09-29 03:26:19 +04:00
f, err := s.walk(nodePath, walkFunc)
2013-09-04 05:27:46 +04:00
if err != nil {
return nil, err
}
return f, nil
}
2013-11-06 09:47:25 +04:00
// deleteExpiredKyes will delete all
func (s *store) DeleteExpiredKeys(cutoff time.Time) {
2013-11-06 09:47:25 +04:00
s.worldLock.Lock()
defer s.worldLock.Unlock()
for {
node := s.ttlKeyHeap.top()
if node == nil || node.ExpireTime.After(cutoff) {
2013-11-07 09:27:39 +04:00
break
2013-11-06 09:47:25 +04:00
}
s.ttlKeyHeap.pop()
2013-12-06 02:10:37 +04:00
node.Remove(true, true, nil)
2013-11-06 09:47:25 +04:00
s.CurrentIndex++
2013-11-06 09:56:21 +04:00
s.Stats.Inc(ExpireCount)
2013-11-28 08:04:52 +04:00
s.WatcherHub.notify(newEvent(Expire, node.Path, s.CurrentIndex, node.CreatedIndex))
2013-11-06 09:47:25 +04:00
}
2013-11-06 09:47:25 +04:00
}
2013-09-03 22:30:42 +04:00
// checkDir function will check whether the component is a directory under parent node.
// If it is a directory, this function will return the pointer to that node.
// If it does not exist, this function will create a new directory and return the pointer to that node.
// If it is a file, this function will return error.
func (s *store) checkDir(parent *node, dirName string) (*node, *etcdErr.Error) {
node, ok := parent.Children[dirName]
2013-09-03 22:30:42 +04:00
if ok {
if node.IsDir() {
return node, nil
}
return nil, etcdErr.NewError(etcdErr.EcodeNotDir, parent.Path, s.CurrentIndex)
2013-09-03 22:30:42 +04:00
}
2013-11-10 08:49:19 +04:00
n := newDir(s, path.Join(parent.Path, dirName), s.CurrentIndex+1, parent, parent.ACL, Permanent)
2013-09-03 22:30:42 +04:00
parent.Children[dirName] = n
return n, nil
}
2013-09-14 01:10:40 +04:00
// Save function saves the static state of the store system.
// Save function will not be able to save the state of watchers.
// Save function will not save the parent field of the node. Or there will
// be cyclic dependencies issue for the json package.
2013-10-14 21:12:30 +04:00
func (s *store) Save() ([]byte, error) {
2013-09-29 03:58:57 +04:00
s.worldLock.Lock()
2013-10-14 21:12:30 +04:00
clonedStore := newStore()
clonedStore.CurrentIndex = s.CurrentIndex
2013-09-29 04:41:45 +04:00
clonedStore.Root = s.Root.Clone()
clonedStore.WatcherHub = s.WatcherHub.clone()
2013-09-29 03:58:57 +04:00
clonedStore.Stats = s.Stats.clone()
2013-10-27 22:47:00 +04:00
clonedStore.CurrentVersion = s.CurrentVersion
2013-09-29 03:58:57 +04:00
s.worldLock.Unlock()
2013-09-14 01:10:40 +04:00
2013-09-29 03:26:19 +04:00
b, err := json.Marshal(clonedStore)
2013-09-14 01:10:40 +04:00
if err != nil {
2013-09-16 06:28:42 +04:00
return nil, err
2013-09-14 01:10:40 +04:00
}
2013-09-16 06:28:42 +04:00
return b, nil
2013-09-14 01:10:40 +04:00
}
// recovery function recovery the store system from a static state.
// It needs to recovery the parent field of the nodes.
// It needs to delete the expired nodes since the saved time and also
// need to create monitor go routines.
2013-10-14 21:12:30 +04:00
func (s *store) Recovery(state []byte) error {
2013-09-29 03:58:57 +04:00
s.worldLock.Lock()
defer s.worldLock.Unlock()
2013-09-29 03:26:19 +04:00
err := json.Unmarshal(state, s)
2013-09-14 01:10:40 +04:00
if err != nil {
2013-09-16 06:28:42 +04:00
return err
2013-09-14 01:10:40 +04:00
}
2013-11-05 09:51:14 +04:00
s.ttlKeyHeap = newTtlKeyHeap()
2013-10-14 21:12:30 +04:00
s.Root.recoverAndclean()
2013-09-16 06:28:42 +04:00
return nil
2013-09-14 01:10:40 +04:00
}
2013-09-29 03:26:19 +04:00
2013-10-14 21:12:30 +04:00
func (s *store) JsonStats() []byte {
2013-09-29 03:26:19 +04:00
s.Stats.Watchers = uint64(s.WatcherHub.count)
return s.Stats.toJson()
}
2013-10-27 22:47:00 +04:00
2013-10-31 02:14:34 +04:00
func (s *store) TotalTransactions() uint64 {
return s.Stats.TotalTranscations()
}