mirror of
https://github.com/openimsdk/open-im-server.git
synced 2025-06-21 19:09:32 +08:00
Merge remote-tracking branch 'origin/localcache' into localcache
# Conflicts: # pkg/common/localcache/cache.go # pkg/common/localcache/option.go
This commit is contained in:
commit
9908e2c658
@ -1,4 +1,4 @@
|
||||
package local
|
||||
package localcache
|
||||
|
||||
import "github.com/hashicorp/golang-lru/v2/simplelru"
|
||||
|
@ -1,50 +0,0 @@
|
||||
package local
|
||||
|
||||
import (
|
||||
"hash/fnv"
|
||||
"time"
|
||||
"unsafe"
|
||||
)
|
||||
|
||||
type Cache[V any] interface {
|
||||
Get(key string, fetch func() (V, error)) (V, error)
|
||||
Del(key string) bool
|
||||
}
|
||||
|
||||
func NewCache[V any](slotNum, slotSize int, successTTL, failedTTL time.Duration, target Target, onEvict EvictCallback[string, V]) Cache[V] {
|
||||
c := &slot[V]{
|
||||
n: uint64(slotNum),
|
||||
slots: make([]*LRU[string, V], slotNum),
|
||||
target: target,
|
||||
}
|
||||
for i := 0; i < slotNum; i++ {
|
||||
c.slots[i] = NewLRU[string, V](slotSize, successTTL, failedTTL, c.target, onEvict)
|
||||
}
|
||||
return c
|
||||
}
|
||||
|
||||
type slot[V any] struct {
|
||||
n uint64
|
||||
slots []*LRU[string, V]
|
||||
target Target
|
||||
}
|
||||
|
||||
func (c *slot[V]) index(s string) uint64 {
|
||||
h := fnv.New64a()
|
||||
_, _ = h.Write(*(*[]byte)(unsafe.Pointer(&s)))
|
||||
return h.Sum64() % c.n
|
||||
}
|
||||
|
||||
func (c *slot[V]) Get(key string, fetch func() (V, error)) (V, error) {
|
||||
return c.slots[c.index(key)].Get(key, fetch)
|
||||
}
|
||||
|
||||
func (c *slot[V]) Del(key string) bool {
|
||||
if c.slots[c.index(key)].Del(key) {
|
||||
c.target.IncrDelHit()
|
||||
return true
|
||||
} else {
|
||||
c.target.IncrDelNotFound()
|
||||
return false
|
||||
}
|
||||
}
|
@ -1,95 +0,0 @@
|
||||
package local
|
||||
|
||||
import (
|
||||
"fmt"
|
||||
"sync"
|
||||
"sync/atomic"
|
||||
"testing"
|
||||
"time"
|
||||
)
|
||||
|
||||
type cacheTarget struct {
|
||||
getHit int64
|
||||
getSuccess int64
|
||||
getFailed int64
|
||||
delHit int64
|
||||
delNotFound int64
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrGetHit() {
|
||||
atomic.AddInt64(&r.getHit, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrGetSuccess() {
|
||||
atomic.AddInt64(&r.getSuccess, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrGetFailed() {
|
||||
atomic.AddInt64(&r.getFailed, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrDelHit() {
|
||||
atomic.AddInt64(&r.delHit, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrDelNotFound() {
|
||||
atomic.AddInt64(&r.delNotFound, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) String() string {
|
||||
return fmt.Sprintf("getHit: %d, getSuccess: %d, getFailed: %d, delHit: %d, delNotFound: %d", r.getHit, r.getSuccess, r.getFailed, r.delHit, r.delNotFound)
|
||||
}
|
||||
|
||||
func TestName(t *testing.T) {
|
||||
target := &cacheTarget{}
|
||||
l := NewCache[string](100, 1000, time.Second*20, time.Second*5, target, nil)
|
||||
//l := NewLRU[string, string](1000, time.Second*20, time.Second*5, target)
|
||||
|
||||
fn := func(key string, n int, fetch func() (string, error)) {
|
||||
for i := 0; i < n; i++ {
|
||||
//v, err := l.Get(key, fetch)
|
||||
//if err == nil {
|
||||
// t.Log("key", key, "value", v)
|
||||
//} else {
|
||||
// t.Error("key", key, err)
|
||||
//}
|
||||
l.Get(key, fetch)
|
||||
//time.Sleep(time.Second / 100)
|
||||
}
|
||||
}
|
||||
|
||||
tmp := make(map[string]struct{})
|
||||
|
||||
var wg sync.WaitGroup
|
||||
for i := 0; i < 10000; i++ {
|
||||
wg.Add(1)
|
||||
key := fmt.Sprintf("key_%d", i%200)
|
||||
tmp[key] = struct{}{}
|
||||
go func() {
|
||||
defer wg.Done()
|
||||
//t.Log(key)
|
||||
fn(key, 10000, func() (string, error) {
|
||||
//time.Sleep(time.Second * 3)
|
||||
//t.Log(time.Now(), "key", key, "fetch")
|
||||
//if rand.Uint32()%5 == 0 {
|
||||
// return "value_" + key, nil
|
||||
//}
|
||||
//return "", errors.New("rand error")
|
||||
return "value_" + key, nil
|
||||
})
|
||||
}()
|
||||
|
||||
//wg.Add(1)
|
||||
//go func() {
|
||||
// defer wg.Done()
|
||||
// for i := 0; i < 10; i++ {
|
||||
// l.Del(key)
|
||||
// time.Sleep(time.Second / 3)
|
||||
// }
|
||||
//}()
|
||||
}
|
||||
wg.Wait()
|
||||
t.Log(len(tmp))
|
||||
t.Log(target.String())
|
||||
|
||||
}
|
@ -1,10 +0,0 @@
|
||||
package local
|
||||
|
||||
type Target interface {
|
||||
IncrGetHit()
|
||||
IncrGetSuccess()
|
||||
IncrGetFailed()
|
||||
|
||||
IncrDelHit()
|
||||
IncrDelNotFound()
|
||||
}
|
@ -1,4 +1,4 @@
|
||||
package local
|
||||
package localcache
|
||||
|
||||
import (
|
||||
"github.com/hashicorp/golang-lru/v2/simplelru"
|
||||
@ -30,6 +30,7 @@ func NewLRU[K comparable, V any](size int, successTTL, failedTTL time.Duration,
|
||||
successTTL: successTTL,
|
||||
failedTTL: failedTTL,
|
||||
target: target,
|
||||
s: NewSingleFlight[K, V](),
|
||||
}
|
||||
}
|
||||
|
||||
@ -39,6 +40,7 @@ type LRU[K comparable, V any] struct {
|
||||
successTTL time.Duration
|
||||
failedTTL time.Duration
|
||||
target Target
|
||||
s *SingleFlight[K, V]
|
||||
}
|
||||
|
||||
func (x *LRU[K, V]) Get(key K, fetch func() (V, error)) (V, error) {
|
||||
@ -78,5 +80,10 @@ func (x *LRU[K, V]) Del(key K) bool {
|
||||
x.lock.Lock()
|
||||
ok := x.core.Remove(key)
|
||||
x.lock.Unlock()
|
||||
if ok {
|
||||
x.target.IncrDelHit()
|
||||
} else {
|
||||
x.target.IncrDelNotFound()
|
||||
}
|
||||
return ok
|
||||
}
|
55
pkg/common/localcache/lru_test.go
Normal file
55
pkg/common/localcache/lru_test.go
Normal file
@ -0,0 +1,55 @@
|
||||
package localcache
|
||||
|
||||
//func TestName(t *testing.T) {
|
||||
// target := &cacheTarget{}
|
||||
// l := NewCache[string](100, 1000, time.Second*20, time.Second*5, target, nil)
|
||||
// //l := NewLRU[string, string](1000, time.Second*20, time.Second*5, target)
|
||||
//
|
||||
// fn := func(key string, n int, fetch func() (string, error)) {
|
||||
// for i := 0; i < n; i++ {
|
||||
// //v, err := l.Get(key, fetch)
|
||||
// //if err == nil {
|
||||
// // t.Log("key", key, "value", v)
|
||||
// //} else {
|
||||
// // t.Error("key", key, err)
|
||||
// //}
|
||||
// l.Get(key, fetch)
|
||||
// //time.Sleep(time.Second / 100)
|
||||
// }
|
||||
// }
|
||||
//
|
||||
// tmp := make(map[string]struct{})
|
||||
//
|
||||
// var wg sync.WaitGroup
|
||||
// for i := 0; i < 10000; i++ {
|
||||
// wg.Add(1)
|
||||
// key := fmt.Sprintf("key_%d", i%200)
|
||||
// tmp[key] = struct{}{}
|
||||
// go func() {
|
||||
// defer wg.Done()
|
||||
// //t.Log(key)
|
||||
// fn(key, 10000, func() (string, error) {
|
||||
// //time.Sleep(time.Second * 3)
|
||||
// //t.Log(time.Now(), "key", key, "fetch")
|
||||
// //if rand.Uint32()%5 == 0 {
|
||||
// // return "value_" + key, nil
|
||||
// //}
|
||||
// //return "", errors.New("rand error")
|
||||
// return "value_" + key, nil
|
||||
// })
|
||||
// }()
|
||||
//
|
||||
// //wg.Add(1)
|
||||
// //go func() {
|
||||
// // defer wg.Done()
|
||||
// // for i := 0; i < 10; i++ {
|
||||
// // l.Del(key)
|
||||
// // time.Sleep(time.Second / 3)
|
||||
// // }
|
||||
// //}()
|
||||
// }
|
||||
// wg.Wait()
|
||||
// t.Log(len(tmp))
|
||||
// t.Log(target.String())
|
||||
//
|
||||
//}
|
43
pkg/common/localcache/singleflight.go
Normal file
43
pkg/common/localcache/singleflight.go
Normal file
@ -0,0 +1,43 @@
|
||||
package localcache
|
||||
|
||||
import "sync"
|
||||
|
||||
type call[K comparable, V any] struct {
|
||||
wg sync.WaitGroup
|
||||
val V
|
||||
err error
|
||||
}
|
||||
|
||||
type SingleFlight[K comparable, V any] struct {
|
||||
mu sync.Mutex
|
||||
m map[K]*call[K, V]
|
||||
}
|
||||
|
||||
func NewSingleFlight[K comparable, V any]() *SingleFlight[K, V] {
|
||||
return &SingleFlight[K, V]{m: make(map[K]*call[K, V])}
|
||||
}
|
||||
|
||||
func (r *SingleFlight[K, V]) Do(key K, fn func() (V, error)) (V, error) {
|
||||
r.mu.Lock()
|
||||
if r.m == nil {
|
||||
r.m = make(map[K]*call[K, V])
|
||||
}
|
||||
if c, ok := r.m[key]; ok {
|
||||
r.mu.Unlock()
|
||||
c.wg.Wait()
|
||||
return c.val, c.err
|
||||
}
|
||||
c := new(call[K, V])
|
||||
c.wg.Add(1)
|
||||
r.m[key] = c
|
||||
r.mu.Unlock()
|
||||
|
||||
c.val, c.err = fn()
|
||||
c.wg.Done()
|
||||
|
||||
r.mu.Lock()
|
||||
delete(r.m, key)
|
||||
r.mu.Unlock()
|
||||
|
||||
return c.val, c.err
|
||||
}
|
59
pkg/common/localcache/target.go
Normal file
59
pkg/common/localcache/target.go
Normal file
@ -0,0 +1,59 @@
|
||||
package localcache
|
||||
|
||||
import (
|
||||
"fmt"
|
||||
"sync/atomic"
|
||||
)
|
||||
|
||||
type Target interface {
|
||||
IncrGetHit()
|
||||
IncrGetSuccess()
|
||||
IncrGetFailed()
|
||||
|
||||
IncrDelHit()
|
||||
IncrDelNotFound()
|
||||
}
|
||||
|
||||
type cacheTarget struct {
|
||||
getHit int64
|
||||
getSuccess int64
|
||||
getFailed int64
|
||||
delHit int64
|
||||
delNotFound int64
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrGetHit() {
|
||||
atomic.AddInt64(&r.getHit, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrGetSuccess() {
|
||||
atomic.AddInt64(&r.getSuccess, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrGetFailed() {
|
||||
atomic.AddInt64(&r.getFailed, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrDelHit() {
|
||||
atomic.AddInt64(&r.delHit, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) IncrDelNotFound() {
|
||||
atomic.AddInt64(&r.delNotFound, 1)
|
||||
}
|
||||
|
||||
func (r *cacheTarget) String() string {
|
||||
return fmt.Sprintf("getHit: %d, getSuccess: %d, getFailed: %d, delHit: %d, delNotFound: %d", r.getHit, r.getSuccess, r.getFailed, r.delHit, r.delNotFound)
|
||||
}
|
||||
|
||||
type emptyTarget struct{}
|
||||
|
||||
func (e emptyTarget) IncrGetHit() {}
|
||||
|
||||
func (e emptyTarget) IncrGetSuccess() {}
|
||||
|
||||
func (e emptyTarget) IncrGetFailed() {}
|
||||
|
||||
func (e emptyTarget) IncrDelHit() {}
|
||||
|
||||
func (e emptyTarget) IncrDelNotFound() {}
|
71
pkg/common/localcache/timingwheel.go
Normal file
71
pkg/common/localcache/timingwheel.go
Normal file
@ -0,0 +1,71 @@
|
||||
package localcache
|
||||
|
||||
import (
|
||||
"sync"
|
||||
"time"
|
||||
)
|
||||
|
||||
type Execute[K comparable, V any] func(K, V)
|
||||
|
||||
type Task[K comparable, V any] struct {
|
||||
key K
|
||||
value V
|
||||
}
|
||||
|
||||
type TimeWheel[K comparable, V any] struct {
|
||||
ticker *time.Ticker
|
||||
slots [][]Task[K, V]
|
||||
currentPos int
|
||||
size int
|
||||
slotMutex sync.Mutex
|
||||
execute Execute[K, V]
|
||||
}
|
||||
|
||||
func NewTimeWheel[K comparable, V any](size int, tickDuration time.Duration, execute Execute[K, V]) *TimeWheel[K, V] {
|
||||
return &TimeWheel[K, V]{
|
||||
ticker: time.NewTicker(tickDuration),
|
||||
slots: make([][]Task[K, V], size),
|
||||
currentPos: 0,
|
||||
size: size,
|
||||
execute: execute,
|
||||
}
|
||||
}
|
||||
|
||||
func (tw *TimeWheel[K, V]) Start() {
|
||||
for range tw.ticker.C {
|
||||
tw.tick()
|
||||
}
|
||||
}
|
||||
|
||||
func (tw *TimeWheel[K, V]) Stop() {
|
||||
tw.ticker.Stop()
|
||||
}
|
||||
|
||||
func (tw *TimeWheel[K, V]) tick() {
|
||||
tw.slotMutex.Lock()
|
||||
defer tw.slotMutex.Unlock()
|
||||
|
||||
tasks := tw.slots[tw.currentPos]
|
||||
tw.slots[tw.currentPos] = nil
|
||||
if len(tasks) > 0 {
|
||||
go func(tasks []Task[K, V]) {
|
||||
for _, task := range tasks {
|
||||
tw.execute(task.key, task.value)
|
||||
}
|
||||
}(tasks)
|
||||
}
|
||||
|
||||
tw.currentPos = (tw.currentPos + 1) % tw.size
|
||||
}
|
||||
|
||||
func (tw *TimeWheel[K, V]) AddTask(delay int, task Task[K, V]) {
|
||||
if delay < 0 || delay >= tw.size {
|
||||
return
|
||||
}
|
||||
|
||||
tw.slotMutex.Lock()
|
||||
defer tw.slotMutex.Unlock()
|
||||
|
||||
pos := (tw.currentPos + delay) % tw.size
|
||||
tw.slots[pos] = append(tw.slots[pos], task)
|
||||
}
|
16
pkg/common/redispubsub/redispubliser.go
Normal file
16
pkg/common/redispubsub/redispubliser.go
Normal file
@ -0,0 +1,16 @@
|
||||
package redispubsub
|
||||
|
||||
import "github.com/redis/go-redis/v9"
|
||||
|
||||
type Publisher struct {
|
||||
client redis.UniversalClient
|
||||
channel string
|
||||
}
|
||||
|
||||
func NewPublisher(client redis.UniversalClient, channel string) *Publisher {
|
||||
return &Publisher{client: client, channel: channel}
|
||||
}
|
||||
|
||||
func (p *Publisher) Publish(message string) error {
|
||||
return p.client.Publish(ctx, p.channel, message).Err()
|
||||
}
|
27
pkg/common/redispubsub/redissubscriber.go
Normal file
27
pkg/common/redispubsub/redissubscriber.go
Normal file
@ -0,0 +1,27 @@
|
||||
package redispubsub
|
||||
|
||||
import (
|
||||
"context"
|
||||
"github.com/redis/go-redis/v9"
|
||||
)
|
||||
|
||||
var ctx = context.Background()
|
||||
|
||||
type Subscriber struct {
|
||||
client redis.UniversalClient
|
||||
channel string
|
||||
}
|
||||
|
||||
func NewSubscriber(client redis.UniversalClient, channel string) *Subscriber {
|
||||
return &Subscriber{client: client, channel: channel}
|
||||
}
|
||||
|
||||
func (s *Subscriber) OnMessage(callback func(string)) error {
|
||||
messageChannel := s.client.Subscribe(ctx, s.channel).Channel()
|
||||
go func() {
|
||||
for msg := range messageChannel {
|
||||
callback(msg.Payload)
|
||||
}
|
||||
}()
|
||||
return nil
|
||||
}
|
Loading…
x
Reference in New Issue
Block a user