2018-04-04 03:46:07 +00:00
|
|
|
// Package cache provides caching features for data from a Consul server.
|
|
|
|
//
|
|
|
|
// While this is similar in some ways to the "agent/ae" package, a key
|
|
|
|
// difference is that with anti-entropy, the agent is the authoritative
|
|
|
|
// source so it resolves differences the server may have. With caching (this
|
|
|
|
// package), the server is the authoritative source and we do our best to
|
|
|
|
// balance performance and correctness, depending on the type of data being
|
|
|
|
// requested.
|
|
|
|
//
|
|
|
|
// Currently, the cache package supports only continuous, blocking query
|
|
|
|
// caching. This means that the cache update is edge-triggered by Consul
|
|
|
|
// server blocking queries.
|
|
|
|
package cache
|
|
|
|
|
|
|
|
import (
|
|
|
|
"fmt"
|
|
|
|
"sync"
|
2018-04-11 09:18:24 +00:00
|
|
|
"sync/atomic"
|
2018-04-04 03:46:07 +00:00
|
|
|
"time"
|
|
|
|
)
|
|
|
|
|
|
|
|
//go:generate mockery -all -inpkg
|
|
|
|
|
|
|
|
// Cache is a agent-local cache of Consul data.
|
|
|
|
type Cache struct {
|
2018-04-11 09:18:24 +00:00
|
|
|
// Keeps track of the cache hits and misses in total. This is used by
|
|
|
|
// tests currently to verify cache behavior and is not meant for general
|
|
|
|
// analytics; for that, go-metrics emitted values are better.
|
|
|
|
hits, misses uint64
|
|
|
|
|
2018-04-10 15:05:34 +00:00
|
|
|
// types stores the list of data types that the cache knows how to service.
|
|
|
|
// These can be dynamically registered with RegisterType.
|
2018-04-04 03:46:07 +00:00
|
|
|
typesLock sync.RWMutex
|
|
|
|
types map[string]typeEntry
|
2018-04-10 15:05:34 +00:00
|
|
|
|
|
|
|
// entries contains the actual cache data.
|
|
|
|
//
|
|
|
|
// NOTE(mitchellh): The entry map key is currently a string in the format
|
|
|
|
// of "<DC>/<ACL token>/<Request key>" in order to properly partition
|
|
|
|
// requests to different datacenters and ACL tokens. This format has some
|
|
|
|
// big drawbacks: we can't evict by datacenter, ACL token, etc. For an
|
|
|
|
// initial implementaiton this works and the tests are agnostic to the
|
|
|
|
// internal storage format so changing this should be possible safely.
|
|
|
|
entriesLock sync.RWMutex
|
|
|
|
entries map[string]cacheEntry
|
2018-04-04 03:46:07 +00:00
|
|
|
}
|
|
|
|
|
2018-04-08 13:30:14 +00:00
|
|
|
// cacheEntry stores a single cache entry.
|
2018-04-04 03:46:07 +00:00
|
|
|
type cacheEntry struct {
|
|
|
|
// Fields pertaining to the actual value
|
|
|
|
Value interface{}
|
|
|
|
Error error
|
|
|
|
Index uint64
|
|
|
|
|
|
|
|
// Metadata that is used for internal accounting
|
|
|
|
Valid bool
|
|
|
|
Fetching bool
|
|
|
|
Waiter chan struct{}
|
|
|
|
}
|
|
|
|
|
|
|
|
// typeEntry is a single type that is registered with a Cache.
|
|
|
|
type typeEntry struct {
|
|
|
|
Type Type
|
|
|
|
Opts *RegisterOptions
|
|
|
|
}
|
|
|
|
|
2018-04-08 13:30:14 +00:00
|
|
|
// Options are options for the Cache.
|
|
|
|
type Options struct {
|
|
|
|
// Nothing currently, reserved.
|
|
|
|
}
|
|
|
|
|
2018-04-04 03:46:07 +00:00
|
|
|
// New creates a new cache with the given RPC client and reasonable defaults.
|
|
|
|
// Further settings can be tweaked on the returned value.
|
2018-04-08 13:30:14 +00:00
|
|
|
func New(*Options) *Cache {
|
2018-04-04 03:46:07 +00:00
|
|
|
return &Cache{
|
2018-04-08 13:30:14 +00:00
|
|
|
entries: make(map[string]cacheEntry),
|
|
|
|
types: make(map[string]typeEntry),
|
2018-04-04 03:46:07 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// RegisterOptions are options that can be associated with a type being
|
|
|
|
// registered for the cache. This changes the behavior of the cache for
|
|
|
|
// this type.
|
|
|
|
type RegisterOptions struct {
|
|
|
|
// Refresh configures whether the data is actively refreshed or if
|
|
|
|
// the data is only refreshed on an explicit Get. The default (false)
|
|
|
|
// is to only request data on explicit Get.
|
|
|
|
Refresh bool
|
|
|
|
|
|
|
|
// RefreshTimer is the time between attempting to refresh data.
|
|
|
|
// If this is zero, then data is refreshed immediately when a fetch
|
|
|
|
// is returned.
|
|
|
|
//
|
|
|
|
// RefreshTimeout determines the maximum query time for a refresh
|
|
|
|
// operation. This is specified as part of the query options and is
|
|
|
|
// expected to be implemented by the Type itself.
|
|
|
|
//
|
|
|
|
// Using these values, various "refresh" mechanisms can be implemented:
|
|
|
|
//
|
|
|
|
// * With a high timer duration and a low timeout, a timer-based
|
|
|
|
// refresh can be set that minimizes load on the Consul servers.
|
|
|
|
//
|
|
|
|
// * With a low timer and high timeout duration, a blocking-query-based
|
|
|
|
// refresh can be set so that changes in server data are recognized
|
|
|
|
// within the cache very quickly.
|
|
|
|
//
|
|
|
|
RefreshTimer time.Duration
|
|
|
|
RefreshTimeout time.Duration
|
|
|
|
}
|
|
|
|
|
|
|
|
// RegisterType registers a cacheable type.
|
|
|
|
func (c *Cache) RegisterType(n string, typ Type, opts *RegisterOptions) {
|
|
|
|
c.typesLock.Lock()
|
|
|
|
defer c.typesLock.Unlock()
|
|
|
|
c.types[n] = typeEntry{Type: typ, Opts: opts}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Get loads the data for the given type and request. If data satisfying the
|
|
|
|
// minimum index is present in the cache, it is returned immediately. Otherwise,
|
|
|
|
// this will block until the data is available or the request timeout is
|
|
|
|
// reached.
|
|
|
|
//
|
|
|
|
// Multiple Get calls for the same Request (matching CacheKey value) will
|
|
|
|
// block on a single network request.
|
|
|
|
func (c *Cache) Get(t string, r Request) (interface{}, error) {
|
2018-04-08 14:08:34 +00:00
|
|
|
info := r.CacheInfo()
|
|
|
|
if info.Key == "" {
|
2018-04-08 13:30:14 +00:00
|
|
|
// If no key is specified, then we do not cache this request.
|
|
|
|
// Pass directly through to the backend.
|
|
|
|
return c.fetchDirect(t, r)
|
|
|
|
}
|
2018-04-04 03:46:07 +00:00
|
|
|
|
2018-04-10 15:05:34 +00:00
|
|
|
// Get the actual key for our entry
|
|
|
|
key := c.entryKey(&info)
|
|
|
|
|
2018-04-11 09:18:24 +00:00
|
|
|
// First time through
|
|
|
|
first := true
|
|
|
|
|
2018-04-04 03:46:07 +00:00
|
|
|
RETRY_GET:
|
|
|
|
// Get the current value
|
|
|
|
c.entriesLock.RLock()
|
2018-04-10 15:05:34 +00:00
|
|
|
entry, ok := c.entries[key]
|
2018-04-04 03:46:07 +00:00
|
|
|
c.entriesLock.RUnlock()
|
|
|
|
|
|
|
|
// If we have a current value and the index is greater than the
|
|
|
|
// currently stored index then we return that right away. If the
|
|
|
|
// index is zero and we have something in the cache we accept whatever
|
|
|
|
// we have.
|
2018-04-08 13:30:14 +00:00
|
|
|
if ok && entry.Valid {
|
2018-04-08 14:08:34 +00:00
|
|
|
if info.MinIndex == 0 || info.MinIndex < entry.Index {
|
2018-04-11 09:18:24 +00:00
|
|
|
if first {
|
|
|
|
atomic.AddUint64(&c.hits, 1)
|
|
|
|
}
|
|
|
|
|
2018-04-08 13:30:14 +00:00
|
|
|
return entry.Value, nil
|
|
|
|
}
|
2018-04-04 03:46:07 +00:00
|
|
|
}
|
|
|
|
|
2018-04-11 09:18:24 +00:00
|
|
|
if first {
|
|
|
|
// Record the miss if its our first time through
|
|
|
|
atomic.AddUint64(&c.misses, 1)
|
|
|
|
}
|
|
|
|
|
|
|
|
// No longer our first time through
|
|
|
|
first = false
|
|
|
|
|
2018-04-04 03:46:07 +00:00
|
|
|
// At this point, we know we either don't have a value at all or the
|
|
|
|
// value we have is too old. We need to wait for new data.
|
2018-04-10 15:05:34 +00:00
|
|
|
waiter, err := c.fetch(t, key, r)
|
2018-04-04 03:46:07 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Wait on our waiter and then retry the cache load
|
|
|
|
<-waiter
|
|
|
|
goto RETRY_GET
|
|
|
|
}
|
|
|
|
|
2018-04-10 15:05:34 +00:00
|
|
|
// entryKey returns the key for the entry in the cache. See the note
|
|
|
|
// about the entry key format in the structure docs for Cache.
|
|
|
|
func (c *Cache) entryKey(r *RequestInfo) string {
|
|
|
|
return fmt.Sprintf("%s/%s/%s", r.Datacenter, r.Token, r.Key)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (c *Cache) fetch(t, key string, r Request) (<-chan struct{}, error) {
|
2018-04-04 03:46:07 +00:00
|
|
|
// Get the type that we're fetching
|
|
|
|
c.typesLock.RLock()
|
|
|
|
tEntry, ok := c.types[t]
|
|
|
|
c.typesLock.RUnlock()
|
|
|
|
if !ok {
|
|
|
|
return nil, fmt.Errorf("unknown type in cache: %s", t)
|
|
|
|
}
|
|
|
|
|
|
|
|
c.entriesLock.Lock()
|
|
|
|
defer c.entriesLock.Unlock()
|
2018-04-10 15:05:34 +00:00
|
|
|
entry, ok := c.entries[key]
|
2018-04-04 03:46:07 +00:00
|
|
|
|
|
|
|
// If we already have an entry and it is actively fetching, then return
|
|
|
|
// the currently active waiter.
|
|
|
|
if ok && entry.Fetching {
|
|
|
|
return entry.Waiter, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// If we don't have an entry, then create it. The entry must be marked
|
|
|
|
// as invalid so that it isn't returned as a valid value for a zero index.
|
|
|
|
if !ok {
|
|
|
|
entry = cacheEntry{Valid: false, Waiter: make(chan struct{})}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Set that we're fetching to true, which makes it so that future
|
|
|
|
// identical calls to fetch will return the same waiter rather than
|
|
|
|
// perform multiple fetches.
|
|
|
|
entry.Fetching = true
|
2018-04-10 15:05:34 +00:00
|
|
|
c.entries[key] = entry
|
2018-04-04 03:46:07 +00:00
|
|
|
|
|
|
|
// The actual Fetch must be performed in a goroutine.
|
|
|
|
go func() {
|
|
|
|
// Start building the new entry by blocking on the fetch.
|
|
|
|
var newEntry cacheEntry
|
|
|
|
result, err := tEntry.Type.Fetch(FetchOptions{
|
|
|
|
MinIndex: entry.Index,
|
|
|
|
}, r)
|
|
|
|
newEntry.Value = result.Value
|
|
|
|
newEntry.Index = result.Index
|
|
|
|
newEntry.Error = err
|
|
|
|
|
|
|
|
// This is a valid entry with a result
|
|
|
|
newEntry.Valid = true
|
|
|
|
|
|
|
|
// Create a new waiter that will be used for the next fetch.
|
|
|
|
newEntry.Waiter = make(chan struct{})
|
|
|
|
|
|
|
|
// Insert
|
|
|
|
c.entriesLock.Lock()
|
2018-04-10 15:05:34 +00:00
|
|
|
c.entries[key] = newEntry
|
2018-04-04 03:46:07 +00:00
|
|
|
c.entriesLock.Unlock()
|
|
|
|
|
|
|
|
// Trigger the waiter
|
|
|
|
close(entry.Waiter)
|
|
|
|
|
|
|
|
// If refresh is enabled, run the refresh in due time. The refresh
|
|
|
|
// below might block, but saves us from spawning another goroutine.
|
|
|
|
if tEntry.Opts != nil && tEntry.Opts.Refresh {
|
2018-04-10 15:05:34 +00:00
|
|
|
c.refresh(tEntry.Opts, t, key, r)
|
2018-04-04 03:46:07 +00:00
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
|
|
|
return entry.Waiter, nil
|
|
|
|
}
|
|
|
|
|
2018-04-08 13:30:14 +00:00
|
|
|
// fetchDirect fetches the given request with no caching.
|
|
|
|
func (c *Cache) fetchDirect(t string, r Request) (interface{}, error) {
|
|
|
|
// Get the type that we're fetching
|
|
|
|
c.typesLock.RLock()
|
|
|
|
tEntry, ok := c.types[t]
|
|
|
|
c.typesLock.RUnlock()
|
|
|
|
if !ok {
|
|
|
|
return nil, fmt.Errorf("unknown type in cache: %s", t)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Fetch it with the min index specified directly by the request.
|
|
|
|
result, err := tEntry.Type.Fetch(FetchOptions{
|
2018-04-08 14:08:34 +00:00
|
|
|
MinIndex: r.CacheInfo().MinIndex,
|
2018-04-08 13:30:14 +00:00
|
|
|
}, r)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Return the result and ignore the rest
|
|
|
|
return result.Value, nil
|
|
|
|
}
|
|
|
|
|
2018-04-10 15:05:34 +00:00
|
|
|
func (c *Cache) refresh(opts *RegisterOptions, t string, key string, r Request) {
|
2018-04-04 03:46:07 +00:00
|
|
|
// Sanity-check, we should not schedule anything that has refresh disabled
|
|
|
|
if !opts.Refresh {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// If we have a timer, wait for it
|
|
|
|
if opts.RefreshTimer > 0 {
|
|
|
|
time.Sleep(opts.RefreshTimer)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Trigger
|
2018-04-10 15:05:34 +00:00
|
|
|
c.fetch(t, key, r)
|
2018-04-04 03:46:07 +00:00
|
|
|
}
|
2018-04-11 09:18:24 +00:00
|
|
|
|
|
|
|
// Returns the number of cache hits. Safe to call concurrently.
|
|
|
|
func (c *Cache) Hits() uint64 {
|
|
|
|
return atomic.LoadUint64(&c.hits)
|
|
|
|
}
|