All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.netflix.evcache.EVCacheInMemoryCache Maven / Gradle / Ivy

The newest version!
package com.netflix.evcache;

import java.util.ArrayList;
import java.util.Collections;
import java.util.List;
import java.util.Map;
import java.util.concurrent.Callable;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.ExecutionException;
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
import java.util.concurrent.ThreadFactory;
import java.util.concurrent.TimeUnit;
import java.util.concurrent.locks.ReentrantReadWriteLock;
import java.util.concurrent.locks.ReentrantReadWriteLock.WriteLock;

import com.netflix.archaius.api.Property;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

import com.google.common.base.Optional;
import com.google.common.cache.Cache;
import com.google.common.cache.CacheBuilder;
import com.google.common.cache.CacheLoader;
import com.google.common.cache.CacheStats;
import com.google.common.cache.LoadingCache;
import com.google.common.util.concurrent.ListenableFuture;
import com.google.common.util.concurrent.ListenableFutureTask;
import com.google.common.util.concurrent.ThreadFactoryBuilder;
import com.netflix.evcache.metrics.EVCacheMetricsFactory;
import com.netflix.evcache.util.EVCacheConfig;
import com.netflix.spectator.api.BasicTag;
import com.netflix.spectator.api.Counter;
import com.netflix.spectator.api.Gauge;
import com.netflix.spectator.api.Id;
import com.netflix.spectator.api.Tag;

import net.spy.memcached.transcoders.Transcoder;

/**
 * An In Memory cache that can be used to hold data for short duration. This is
 * helpful when the same key is repeatedly requested from EVCache within a short
 * duration. This can be turned on dynamically and can relive pressure on
 * EVCache Server instances.
 */
public class EVCacheInMemoryCache {

    private static final Logger log = LoggerFactory.getLogger(EVCacheInMemoryCache.class);
    private final Property _cacheDuration; // The key will be cached for this long
    private final Property _refreshDuration, _exireAfterAccessDuration;
    private final Property _cacheSize; // This many items will be cached
    private final Property _poolSize; // This many threads will be initialized to fetch data from evcache async
    private final String appName;
    private final Map counterMap = new ConcurrentHashMap();
    private final Map gaugeMap = new ConcurrentHashMap();

    private LoadingCache> cache;
    private ExecutorService pool = null;

    private final Transcoder tc;
    private final EVCacheImpl impl;
    private final Id sizeId;

    public EVCacheInMemoryCache(String appName, Transcoder tc, EVCacheImpl impl) {
        this.appName = appName;
        this.tc = tc;
        this.impl = impl;

        this._cacheDuration = EVCacheConfig.getInstance().getPropertyRepository().get(appName + ".inmemory.expire.after.write.duration.ms", Integer.class).orElseGet(appName + ".inmemory.cache.duration.ms").orElse(0);
        this._cacheDuration.subscribe((i) -> setupCache());
        this._exireAfterAccessDuration = EVCacheConfig.getInstance().getPropertyRepository().get(appName + ".inmemory.expire.after.access.duration.ms", Integer.class).orElse(0);
        this._exireAfterAccessDuration.subscribe((i) -> setupCache());;

        this._refreshDuration = EVCacheConfig.getInstance().getPropertyRepository().get(appName + ".inmemory.refresh.after.write.duration.ms", Integer.class).orElse(0);
        this._refreshDuration.subscribe((i) -> setupCache());

        this._cacheSize = EVCacheConfig.getInstance().getPropertyRepository().get(appName + ".inmemory.cache.size", Integer.class).orElse(100);
        this._cacheSize.subscribe((i) -> setupCache());

        this._poolSize = EVCacheConfig.getInstance().getPropertyRepository().get(appName + ".thread.pool.size", Integer.class).orElse(5);
        this._poolSize.subscribe((i) -> initRefreshPool());

        final List tags = new ArrayList(3);
        tags.addAll(impl.getTags());
        tags.add(new BasicTag(EVCacheMetricsFactory.METRIC, "size"));

        this.sizeId = EVCacheMetricsFactory.getInstance().getId(EVCacheMetricsFactory.IN_MEMORY, tags);
        setupCache();
        setupMonitoring(appName);
    }

    private WriteLock writeLock = new ReentrantReadWriteLock().writeLock();
    private void initRefreshPool() {
        final ExecutorService oldPool = pool;
        writeLock.lock();
        try {
            final ThreadFactory factory = new ThreadFactoryBuilder().setDaemon(true).setNameFormat(
                    "EVCacheInMemoryCache-%d").build();
            pool = Executors.newFixedThreadPool(_poolSize.get(), factory);
            if(oldPool != null) oldPool.shutdown();
        } finally {
            writeLock.unlock();
        }
    }


    private void setupCache() {
        try {
            CacheBuilder builder = CacheBuilder.newBuilder().recordStats();
            if(_cacheSize.get() > 0) {
                builder = builder.maximumSize(_cacheSize.get());
            }
            if(_exireAfterAccessDuration.get() > 0) {
                builder = builder.expireAfterAccess(_exireAfterAccessDuration.get(), TimeUnit.MILLISECONDS);
            } else if(_cacheDuration.get().intValue() > 0) {
                builder = builder.expireAfterWrite(_cacheDuration.get(), TimeUnit.MILLISECONDS);
            }

            if(_refreshDuration.get() > 0) {
                builder = builder.refreshAfterWrite(_refreshDuration.get(), TimeUnit.MILLISECONDS);
            }
            initRefreshPool();
            final LoadingCache> newCache = builder.build(
                    new CacheLoader>() {
                        public Optional load(EVCacheKey key) throws  EVCacheException, DataNotFoundException {
                            try {
                                return  Optional.fromNullable(impl.doGet(key, tc));
                            } catch (EVCacheException e) {
                                log.error("EVCacheException while loading key -> "+ key, e);
                                throw e;
                            } catch (Exception e) {
                                log.error("EVCacheException while loading key -> "+ key, e);
                                throw new EVCacheException("key : " + key + " could not be loaded", e);
                            }
                        }

                        @Override
                        public ListenableFuture> reload(EVCacheKey key, Optional oldValue) {
                            ListenableFutureTask> task = ListenableFutureTask.create(new Callable>() {
                                public Optional call() {
                                    try {
                                        final Optional t = load(key);
                                        if(t == null) {
                                            EVCacheMetricsFactory.getInstance().increment("EVCacheInMemoryCache" + "-" + appName + "-Reload-NotFound");
                                            return oldValue;
                                        } else {
                                            EVCacheMetricsFactory.getInstance().increment("EVCacheInMemoryCache" + "-" + appName + "-Reload-Success");
                                        }
                                        return t;
                                    } catch (EVCacheException e) {
                                        log.error("EVCacheException while reloading key -> "+ key, e);
                                        EVCacheMetricsFactory.getInstance().increment("EVCacheInMemoryCache" + "-" + appName + "-Reload-Fail");
                                        return oldValue;
                                    }
                                }
                            });
                            pool.execute(task);
                            return task;
                        }
                    });
            if(cache != null) newCache.putAll(cache.asMap());
            final Cache> currentCache = this.cache;
            this.cache = newCache;
            if(currentCache != null) {
                currentCache.invalidateAll();
                currentCache.cleanUp();
            }
        } catch (Exception e) {
            log.error(e.getMessage(), e);
        }
    }

    private CacheStats previousStats = null;
    private long getSize() {
        final long size = cache.size();
        final CacheStats stats = cache.stats();
        if(previousStats != null) {
            try {
                getCounter("hits").increment(stats.hitCount() - previousStats.hitCount());
                getCounter("miss").increment(stats.missCount()  - previousStats.missCount());
                getCounter("evictions").increment(stats.evictionCount()  - previousStats.evictionCount());
                getCounter("requests").increment(stats.requestCount()  - previousStats.requestCount());
        
                getCounter("loadExceptionCount").increment(stats.loadExceptionCount()  - previousStats.loadExceptionCount());
                getCounter("loadCount").increment(stats.loadCount()  - previousStats.loadCount());
                getCounter("loadSuccessCount").increment(stats.loadSuccessCount()  - previousStats.loadSuccessCount());
                getCounter("totalLoadTime-ms").increment(( stats.totalLoadTime() - previousStats.totalLoadTime())/1000000);
        
                getGauge("hitrate").set(stats.hitRate());
                getGauge("loadExceptionRate").set(stats.loadExceptionRate());
                getGauge("averageLoadTime-ms").set(stats.averageLoadPenalty()/1000000);
            } catch(Exception e) {
                log.error("Error while reporting stats", e);
            }
        }
        previousStats = stats;
        return size;
    }

    @SuppressWarnings("deprecation")
    private void setupMonitoring(final String appName) {
        EVCacheMetricsFactory.getInstance().getRegistry().gauge(sizeId, this, EVCacheInMemoryCache::getSize);
    }

    private Counter getCounter(String name) {
        Counter counter = counterMap.get(name);
        if(counter != null) return counter;

        final List tags = new ArrayList(3);
        tags.addAll(impl.getTags());
        tags.add(new BasicTag(EVCacheMetricsFactory.METRIC, name));
        counter = EVCacheMetricsFactory.getInstance().getCounter(EVCacheMetricsFactory.IN_MEMORY, tags);
        counterMap.put(name, counter);
        return counter;
    }

    private Gauge getGauge(String name) {
        Gauge gauge = gaugeMap.get(name);
        if(gauge != null) return gauge;

        final List tags = new ArrayList(3);
        tags.addAll(impl.getTags());
        tags.add(new BasicTag(EVCacheMetricsFactory.METRIC, name));

        final Id id = EVCacheMetricsFactory.getInstance().getId(EVCacheMetricsFactory.IN_MEMORY, tags);
        gauge = EVCacheMetricsFactory.getInstance().getRegistry().gauge(id);
        gaugeMap.put(name, gauge);
        return gauge;
    }

    public T get(EVCacheKey key) throws ExecutionException {
        if (cache == null) return null;
        final Optional val = cache.get(key);
        if(!val.isPresent()) return null;
        if (log.isDebugEnabled()) log.debug("GET : appName : " + appName + "; Key : " + key + "; val : " + val);
        return val.get();
    }

    public void put(EVCacheKey key, T value) {
        if (cache == null) return;
        cache.put(key, Optional.fromNullable(value));
        if (log.isDebugEnabled()) log.debug("PUT : appName : " + appName + "; Key : " + key + "; val : " + value);
    }

    public void delete(String key) {
        if (cache == null) return;
        cache.invalidate(key);
        if (log.isDebugEnabled()) log.debug("DEL : appName : " + appName + "; Key : " + key);
    }

    public Map> getAll() {
        if (cache == null) return Collections.>emptyMap();
        return cache.asMap();
    }

    public static final class DataNotFoundException extends EVCacheException {
        private static final long serialVersionUID = 1800185311509130263L;

        public DataNotFoundException(String message) {
            super(message);
        }
    }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy