mirror of
https://github.com/charlienet/go-mixed.git
synced 2025-07-18 00:22:41 +08:00
Compare commits
5 Commits
Author | SHA1 | Date | |
---|---|---|---|
b4ac1cc449 | |||
1abde30d8f | |||
822932fe15 | |||
85c5a611e1 | |||
fe5c0b54b6 |
@ -2,22 +2,21 @@ package bloom
|
||||
|
||||
import (
|
||||
"context"
|
||||
"sync"
|
||||
|
||||
"github.com/bits-and-blooms/bitset"
|
||||
"github.com/charlienet/go-mixed/locker"
|
||||
)
|
||||
|
||||
type memStore struct {
|
||||
size uint
|
||||
set *bitset.BitSet // 内存位图
|
||||
lock locker.RWLocker // 同步锁
|
||||
set *bitset.BitSet // 内存位图
|
||||
lock sync.RWMutex // 同步锁
|
||||
}
|
||||
|
||||
func newMemStore(size uint) *memStore {
|
||||
return &memStore{
|
||||
size: size,
|
||||
set: bitset.New(size),
|
||||
lock: locker.RWLocker{},
|
||||
}
|
||||
}
|
||||
|
||||
|
@ -6,10 +6,17 @@ type ChanLocker interface {
|
||||
}
|
||||
|
||||
type chanSourceLock struct {
|
||||
m RWLocker
|
||||
m rwLocker
|
||||
content map[string]chan int
|
||||
}
|
||||
|
||||
func NewChanSourceLocker() *chanSourceLock {
|
||||
return &chanSourceLock{
|
||||
m: NewRWLocker(),
|
||||
content: make(map[string]chan int),
|
||||
}
|
||||
}
|
||||
|
||||
func (s *chanSourceLock) Get(key string) (ch <-chan int, ok bool) {
|
||||
s.m.RLock()
|
||||
ch, ok = s.content[key]
|
||||
|
19
locker/chan_source_locker_test.go
Normal file
19
locker/chan_source_locker_test.go
Normal file
@ -0,0 +1,19 @@
|
||||
package locker_test
|
||||
|
||||
import (
|
||||
"testing"
|
||||
|
||||
"github.com/charlienet/go-mixed/locker"
|
||||
)
|
||||
|
||||
func TestChanSourceLocker(t *testing.T) {
|
||||
l := locker.NewChanSourceLocker()
|
||||
c, ok := l.Get("aaaa")
|
||||
if ok {
|
||||
<-c
|
||||
|
||||
println("ok")
|
||||
}
|
||||
|
||||
println("fail")
|
||||
}
|
7
locker/distributed_locker.go
Normal file
7
locker/distributed_locker.go
Normal file
@ -0,0 +1,7 @@
|
||||
package locker
|
||||
|
||||
import "context"
|
||||
|
||||
type DistributedLocker interface {
|
||||
Unlock(context.Context, string)
|
||||
}
|
13
locker/distributed_locker_test.go
Normal file
13
locker/distributed_locker_test.go
Normal file
@ -0,0 +1,13 @@
|
||||
package locker_test
|
||||
|
||||
import (
|
||||
"testing"
|
||||
|
||||
"github.com/charlienet/go-mixed/redis"
|
||||
"github.com/charlienet/go-mixed/tests"
|
||||
)
|
||||
|
||||
func TestRedisDistrbutedLocker(t *testing.T) {
|
||||
tests.RunOnDefaultRedis(t, func(rdb redis.Client) {
|
||||
})
|
||||
}
|
@ -1,14 +1,9 @@
|
||||
package locker
|
||||
|
||||
var _ RWLocker = &emptyLocker{}
|
||||
var _ Locker = &emptyLocker{}
|
||||
var _ rwLocker = &emptyLocker{}
|
||||
var _ locker = &emptyLocker{}
|
||||
|
||||
var EmptyLocker = &emptyLocker{}
|
||||
|
||||
type emptyLocker struct{}
|
||||
|
||||
func NewEmptyLocker() *emptyLocker {
|
||||
return &emptyLocker{}
|
||||
type emptyLocker struct {
|
||||
}
|
||||
|
||||
func (l *emptyLocker) RLock() {}
|
||||
|
@ -2,14 +2,16 @@ package locker
|
||||
|
||||
import "sync"
|
||||
|
||||
type Locker interface {
|
||||
type locker interface {
|
||||
Lock()
|
||||
Unlock()
|
||||
TryLock() bool
|
||||
}
|
||||
|
||||
type RWLocker interface {
|
||||
Locker
|
||||
type rwLocker interface {
|
||||
Lock()
|
||||
Unlock()
|
||||
TryLock() bool
|
||||
RLock()
|
||||
RUnlock()
|
||||
TryRLock() bool
|
||||
@ -18,3 +20,7 @@ type RWLocker interface {
|
||||
func NewLocker() *sync.Mutex {
|
||||
return &sync.Mutex{}
|
||||
}
|
||||
|
||||
func NewRWLocker() *sync.RWMutex {
|
||||
return &sync.RWMutex{}
|
||||
}
|
||||
|
22
locker/readme.md
Normal file
22
locker/readme.md
Normal file
@ -0,0 +1,22 @@
|
||||
同步锁
|
||||
|
||||
EmptyLocker, 空锁
|
||||
RWLocker, 读写锁
|
||||
SpinLocker, 旋转锁
|
||||
|
||||
|
||||
锁可以添加一个外部存储成为分布式锁。WithRedis, WithZookeeper
|
||||
|
||||
单例锁
|
||||
|
||||
|
||||
资源锁
|
||||
|
||||
|
||||
分布式锁
|
||||
在锁的基础上添加分布式存储升级为分布式锁
|
||||
|
||||
locker.WithRedis()
|
||||
locker.WithZookeeper()
|
||||
|
||||
|
33
locker/redis/redis_locker.lua
Normal file
33
locker/redis/redis_locker.lua
Normal file
@ -0,0 +1,33 @@
|
||||
#!lua name=charlie_locker
|
||||
|
||||
-- 安装命令
|
||||
-- cat redis_locker.lua | redis-cli -x --cluster-only-masters --cluster call 192.168.123.30:6379 FUNCTION LOAD REPLACE
|
||||
|
||||
local function lock(keys, args)
|
||||
if redis.call("GET", keys[1]) == args[1] then
|
||||
redis.call("SET", keys[1], args[1], "PX", args[2])
|
||||
return "OK"
|
||||
else
|
||||
return redis.call("SET", keys[1], args[1], "NX", "PX", args[2])
|
||||
end
|
||||
end
|
||||
|
||||
local function del(keys, args)
|
||||
if redis.call("GET", keys[1]) == args[1] then
|
||||
return redis.call("DEL", keys[1])
|
||||
else
|
||||
return '0'
|
||||
end
|
||||
end
|
||||
|
||||
local function expire(keys, args)
|
||||
if redis.call('get', keys[1]) == args[1] then
|
||||
return redis.call('expire', keys[1], args[2])
|
||||
else
|
||||
return '0'
|
||||
end
|
||||
end
|
||||
|
||||
redis.register_function('locker_lock',lock)
|
||||
redis.register_function('locker_unlock',del)
|
||||
redis.register_function('locker_expire',expire)
|
164
locker/redis/redis_store.go
Normal file
164
locker/redis/redis_store.go
Normal file
@ -0,0 +1,164 @@
|
||||
package redis
|
||||
|
||||
import (
|
||||
"context"
|
||||
_ "embed"
|
||||
"maps"
|
||||
"strings"
|
||||
"sync"
|
||||
"time"
|
||||
|
||||
"github.com/charlienet/go-mixed/rand"
|
||||
"github.com/charlienet/go-mixed/redis"
|
||||
goredis "github.com/redis/go-redis/v9"
|
||||
)
|
||||
|
||||
//go:embed redis_locker.lua
|
||||
var redis_locker_function string
|
||||
|
||||
const (
|
||||
defaultExpire = time.Second * 20
|
||||
retryInterval = time.Millisecond * 10
|
||||
)
|
||||
|
||||
var once sync.Once
|
||||
|
||||
type redis_locker_store struct {
|
||||
key string
|
||||
sources map[string]string
|
||||
expire time.Duration // 过期时间
|
||||
mu sync.RWMutex
|
||||
clients []redis.Client
|
||||
}
|
||||
|
||||
func NewRedisStore(key string, clients ...redis.Client) *redis_locker_store {
|
||||
once.Do(func() { redis.Clients(clients).LoadFunction(redis_locker_function) })
|
||||
|
||||
locker := &redis_locker_store{
|
||||
key: key,
|
||||
sources: make(map[string]string),
|
||||
clients: clients,
|
||||
expire: defaultExpire,
|
||||
}
|
||||
|
||||
go locker.expandLockTime()
|
||||
|
||||
return locker
|
||||
}
|
||||
|
||||
func (l *redis_locker_store) Lock(ctx context.Context, sourceName string) error {
|
||||
for {
|
||||
select {
|
||||
case <-ctx.Done():
|
||||
return ctx.Err()
|
||||
default:
|
||||
if l.TryLock(ctx, sourceName) {
|
||||
return nil
|
||||
}
|
||||
}
|
||||
|
||||
time.Sleep(retryInterval)
|
||||
}
|
||||
}
|
||||
|
||||
func (l *redis_locker_store) TryLock(ctx context.Context, sourceName string) bool {
|
||||
value := l.getSourceValue(sourceName)
|
||||
|
||||
results := l.fCall(ctx, "locker_lock", sourceName, value, l.expire.Milliseconds())
|
||||
|
||||
if !isSuccess(results) {
|
||||
for _, r := range results {
|
||||
if r.Err() != nil {
|
||||
println("err:", r.Err().Error())
|
||||
}
|
||||
}
|
||||
|
||||
l.Unlock(ctx, sourceName)
|
||||
return false
|
||||
}
|
||||
|
||||
return true
|
||||
}
|
||||
|
||||
func (locker *redis_locker_store) Unlock(ctx context.Context, sourceName string) {
|
||||
value := locker.getSourceValue(sourceName)
|
||||
locker.fCall(ctx, "locker_unlock", sourceName, value)
|
||||
|
||||
locker.mu.Lock()
|
||||
defer locker.mu.Unlock()
|
||||
|
||||
delete(locker.sources, sourceName)
|
||||
}
|
||||
|
||||
func (l *redis_locker_store) expandLockTime() {
|
||||
for {
|
||||
time.Sleep(l.expire / 3)
|
||||
|
||||
if len(l.sources) == 0 {
|
||||
continue
|
||||
}
|
||||
|
||||
l.mu.RLock()
|
||||
cloned := maps.Clone(l.sources)
|
||||
l.mu.RUnlock()
|
||||
|
||||
for k, v := range cloned {
|
||||
results := l.fCall(context.Background(), "locker_expire", k, v, l.expire.Seconds())
|
||||
for _, r := range results {
|
||||
if r.Err() != nil {
|
||||
println("键延期失败:", r.Err().Error())
|
||||
}
|
||||
}
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
func (l *redis_locker_store) getSourceValue(name string) string {
|
||||
l.mu.Lock()
|
||||
defer l.mu.Unlock()
|
||||
|
||||
if v, ok := l.sources[name]; ok {
|
||||
return v
|
||||
}
|
||||
|
||||
v := rand.Hex.Generate(36)
|
||||
l.sources[name] = v
|
||||
return v
|
||||
}
|
||||
|
||||
func (locker *redis_locker_store) fCall(ctx context.Context, cmd string, key string, args ...any) []*goredis.Cmd {
|
||||
results := make([]*goredis.Cmd, 0, len(locker.clients))
|
||||
|
||||
var wg sync.WaitGroup
|
||||
wg.Add(len(locker.clients))
|
||||
for _, rdb := range locker.clients {
|
||||
go func(rdb redis.Client) {
|
||||
defer wg.Done()
|
||||
|
||||
newKey := rdb.JoinKeys(locker.key, key)
|
||||
results = append(results, rdb.FCall(ctx, cmd, []string{newKey}, args...))
|
||||
}(rdb)
|
||||
}
|
||||
|
||||
wg.Wait()
|
||||
|
||||
return results
|
||||
}
|
||||
|
||||
func isSuccess(results []*goredis.Cmd) bool {
|
||||
successCount := 0
|
||||
for _, ret := range results {
|
||||
resp, err := ret.Result()
|
||||
|
||||
if err != nil || resp == nil {
|
||||
return false
|
||||
}
|
||||
|
||||
reply, ok := resp.(string)
|
||||
if ok && strings.EqualFold(reply, "OK") {
|
||||
successCount++
|
||||
}
|
||||
}
|
||||
|
||||
return successCount >= len(results)/2+1
|
||||
}
|
31
locker/redis/redis_store_test.go
Normal file
31
locker/redis/redis_store_test.go
Normal file
@ -0,0 +1,31 @@
|
||||
package redis
|
||||
|
||||
import (
|
||||
"context"
|
||||
"testing"
|
||||
"time"
|
||||
|
||||
"github.com/charlienet/go-mixed/redis"
|
||||
"github.com/charlienet/go-mixed/tests"
|
||||
)
|
||||
|
||||
func TestCreateRedisStore(t *testing.T) {
|
||||
tests.RunOnDefaultRedis(t, func(rdb redis.Client) {
|
||||
keyName := "source"
|
||||
|
||||
l := NewRedisStore("locker_key", rdb)
|
||||
ret := l.TryLock(context.Background(), keyName)
|
||||
if !ret {
|
||||
t.Log("加锁失败")
|
||||
}
|
||||
|
||||
l.Lock(context.Background(), keyName)
|
||||
t.Log("锁重入完成")
|
||||
|
||||
l.Unlock(context.Background(), keyName)
|
||||
|
||||
time.Sleep(time.Second * 15)
|
||||
|
||||
// l.Unlock(context.Background())
|
||||
})
|
||||
}
|
@ -1,7 +0,0 @@
|
||||
package locker
|
||||
|
||||
import "sync"
|
||||
|
||||
func NewRWLocker() *sync.RWMutex {
|
||||
return &sync.RWMutex{}
|
||||
}
|
@ -1,12 +0,0 @@
|
||||
package locker
|
||||
|
||||
import "testing"
|
||||
|
||||
func TestRWLokcer(t *testing.T) {
|
||||
l := NewRWLocker()
|
||||
l.RLock()
|
||||
|
||||
t.Log(l.TryRLock())
|
||||
|
||||
l.RUnlock()
|
||||
}
|
@ -1,27 +1,45 @@
|
||||
package locker
|
||||
|
||||
import (
|
||||
"context"
|
||||
"fmt"
|
||||
"sync/atomic"
|
||||
|
||||
redis_store "github.com/charlienet/go-mixed/locker/redis"
|
||||
"github.com/charlienet/go-mixed/redis"
|
||||
)
|
||||
|
||||
// 带计数器锁
|
||||
type countLocker struct {
|
||||
Locker
|
||||
rw rwLocker
|
||||
Count int32
|
||||
}
|
||||
|
||||
// SourceLocker 资源锁
|
||||
type SourceLocker struct {
|
||||
m RWLocker
|
||||
locks map[string]*countLocker
|
||||
m RWLocker
|
||||
distributedLocker DistributedLocker
|
||||
locks map[string]*countLocker
|
||||
err error
|
||||
}
|
||||
|
||||
func NewSourceLocker() *SourceLocker {
|
||||
return &SourceLocker{
|
||||
m: NewRWLocker(),
|
||||
l := &SourceLocker{
|
||||
locks: make(map[string]*countLocker),
|
||||
}
|
||||
|
||||
l.m.Synchronize()
|
||||
return l
|
||||
}
|
||||
|
||||
func (s *SourceLocker) WithRedis(key string, clients ...redis.Client) *SourceLocker {
|
||||
redisStore := redis_store.NewRedisStore(key, clients...)
|
||||
return s.WithDistributedLocker(redisStore)
|
||||
}
|
||||
|
||||
func (s *SourceLocker) WithDistributedLocker(distributed DistributedLocker) *SourceLocker {
|
||||
s.distributedLocker = distributed
|
||||
return s
|
||||
}
|
||||
|
||||
func (s *SourceLocker) Lock(key string) {
|
||||
@ -31,7 +49,7 @@ func (s *SourceLocker) Lock(key string) {
|
||||
|
||||
if ok {
|
||||
atomic.AddInt32(&l.Count, 1)
|
||||
l.Lock()
|
||||
l.rw.Lock()
|
||||
|
||||
fmt.Println("加锁")
|
||||
} else {
|
||||
@ -40,18 +58,15 @@ func (s *SourceLocker) Lock(key string) {
|
||||
if l2, ok := s.locks[key]; ok {
|
||||
s.m.Unlock()
|
||||
|
||||
l2.Lock()
|
||||
l2.rw.Lock()
|
||||
fmt.Println("二次检查加锁")
|
||||
} else {
|
||||
n := NewLocker()
|
||||
s.locks[key] = &countLocker{Locker: n, Count: 1}
|
||||
n := NewRWLocker()
|
||||
s.locks[key] = &countLocker{rw: n, Count: 1}
|
||||
|
||||
s.m.Unlock()
|
||||
|
||||
fmt.Printf("新锁准备加锁:%p\n", n)
|
||||
n.Lock()
|
||||
|
||||
fmt.Println("初始加锁")
|
||||
}
|
||||
}
|
||||
}
|
||||
@ -61,8 +76,11 @@ func (s *SourceLocker) Unlock(key string) {
|
||||
|
||||
if l, ok := s.locks[key]; ok {
|
||||
atomic.AddInt32(&l.Count, -1)
|
||||
fmt.Printf("解锁%p\n", l)
|
||||
l.Unlock()
|
||||
l.rw.Unlock()
|
||||
|
||||
if s.distributedLocker != nil {
|
||||
s.distributedLocker.Unlock(context.Background(), key)
|
||||
}
|
||||
|
||||
if l.Count == 0 {
|
||||
delete(s.locks, key)
|
||||
@ -75,18 +93,14 @@ func (s *SourceLocker) TryLock(key string) bool {
|
||||
// 加读锁
|
||||
s.m.RLock()
|
||||
l, ok := s.locks[key]
|
||||
|
||||
s.m.RUnlock()
|
||||
if ok {
|
||||
ret := l.TryLock()
|
||||
s.m.RUnlock()
|
||||
|
||||
ret := l.rw.TryLock()
|
||||
return ret
|
||||
} else {
|
||||
s.m.RUnlock()
|
||||
|
||||
s.m.Lock()
|
||||
n := NewLocker()
|
||||
s.locks[key] = &countLocker{Locker: n, Count: 1}
|
||||
n := NewRWLocker()
|
||||
s.locks[key] = &countLocker{rw: n, Count: 1}
|
||||
s.m.Unlock()
|
||||
|
||||
return n.TryLock()
|
||||
|
@ -1,19 +1,39 @@
|
||||
package locker
|
||||
package locker_test
|
||||
|
||||
import (
|
||||
"sync"
|
||||
"testing"
|
||||
"time"
|
||||
|
||||
"github.com/charlienet/go-mixed/locker"
|
||||
"github.com/stretchr/testify/assert"
|
||||
)
|
||||
|
||||
var sourcekey = "u-0001"
|
||||
|
||||
func TestTryLock(t *testing.T) {
|
||||
l := locker.NewSourceLocker()
|
||||
l.Lock("aa")
|
||||
|
||||
assert.False(t, l.TryLock("aa"))
|
||||
assert.True(t, l.TryLock("bb"))
|
||||
|
||||
defer l.Unlock("aa")
|
||||
}
|
||||
|
||||
func TestM(t *testing.T) {
|
||||
l := locker.NewSourceLocker()
|
||||
|
||||
for i := 0; i < 10000000; i++ {
|
||||
l.Lock("aaa")
|
||||
l.Unlock("aaa")
|
||||
}
|
||||
|
||||
t.Logf("%+v", l)
|
||||
}
|
||||
|
||||
func TestSourceLocker(t *testing.T) {
|
||||
l := NewSourceLocker()
|
||||
l := locker.NewSourceLocker()
|
||||
|
||||
c := 5
|
||||
n := 0
|
||||
@ -41,7 +61,7 @@ func TestSourceTryLock(t *testing.T) {
|
||||
wg := new(sync.WaitGroup)
|
||||
wg.Add(c)
|
||||
|
||||
l := NewSourceLocker()
|
||||
l := locker.NewSourceLocker()
|
||||
|
||||
for i := 0; i < c; i++ {
|
||||
go func() {
|
||||
@ -61,7 +81,7 @@ func TestSourceTryLock(t *testing.T) {
|
||||
}
|
||||
|
||||
func BenchmarkSourceLocker(b *testing.B) {
|
||||
l := NewSourceLocker()
|
||||
l := locker.NewSourceLocker()
|
||||
|
||||
b.RunParallel(func(p *testing.PB) {
|
||||
for p.Next() {
|
||||
|
@ -1,12 +1,14 @@
|
||||
package locker
|
||||
package locker_test
|
||||
|
||||
import (
|
||||
"sync"
|
||||
"testing"
|
||||
|
||||
"github.com/charlienet/go-mixed/locker"
|
||||
)
|
||||
|
||||
func TestSpinLock(t *testing.T) {
|
||||
l := NewSpinLocker()
|
||||
l := locker.NewSpinLocker()
|
||||
|
||||
n := 10
|
||||
c := 0
|
||||
|
@ -3,94 +3,111 @@ package locker
|
||||
import (
|
||||
"log"
|
||||
"sync"
|
||||
|
||||
"github.com/charlienet/go-mixed/redis"
|
||||
)
|
||||
|
||||
type WithLocker struct {
|
||||
once sync.Once
|
||||
mu Locker
|
||||
var empty = &emptyLocker{}
|
||||
|
||||
type Locker struct {
|
||||
once sync.Once
|
||||
distributedLocker DistributedLocker // 分布式锁
|
||||
mu locker
|
||||
}
|
||||
|
||||
func (w *WithLocker) Synchronize() {
|
||||
if w.mu == nil || w.mu == EmptyLocker {
|
||||
func (w *Locker) WithRedis(key string, rdb redis.Client) *Locker {
|
||||
return w
|
||||
}
|
||||
|
||||
func (w *Locker) WithDistributedLocker(d DistributedLocker) *Locker {
|
||||
return w
|
||||
}
|
||||
|
||||
func (w *Locker) Synchronize() *Locker {
|
||||
if w.mu == nil || w.mu == empty {
|
||||
w.mu = NewLocker()
|
||||
}
|
||||
|
||||
return w
|
||||
}
|
||||
|
||||
func (w *WithLocker) Lock() {
|
||||
w.ensureLocker().Lock()
|
||||
func (w *Locker) Lock() {
|
||||
w.ensureLocker().mu.Lock()
|
||||
}
|
||||
|
||||
func (w *WithLocker) Unlock() {
|
||||
w.ensureLocker().Unlock()
|
||||
func (w *Locker) Unlock() {
|
||||
w.ensureLocker().mu.Unlock()
|
||||
}
|
||||
|
||||
func (w *WithLocker) TryLock() bool {
|
||||
return w.ensureLocker().TryLock()
|
||||
func (w *Locker) TryLock() bool {
|
||||
return w.ensureLocker().mu.TryLock()
|
||||
}
|
||||
|
||||
func (w *WithLocker) ensureLocker() Locker {
|
||||
func (w *Locker) ensureLocker() *Locker {
|
||||
w.once.Do(func() {
|
||||
if w.mu == nil {
|
||||
w.mu = EmptyLocker
|
||||
w.mu = empty
|
||||
}
|
||||
|
||||
})
|
||||
|
||||
return w.mu
|
||||
return w
|
||||
}
|
||||
|
||||
type WithSpinLocker struct {
|
||||
WithLocker
|
||||
type SpinLocker struct {
|
||||
Locker
|
||||
}
|
||||
|
||||
func (w *WithSpinLocker) Synchronize() {
|
||||
if w.mu == nil || w.mu == EmptyLocker {
|
||||
func (w *SpinLocker) Synchronize() {
|
||||
if w.mu == nil || w.mu == empty {
|
||||
w.mu = NewSpinLocker()
|
||||
}
|
||||
}
|
||||
|
||||
type WithRWLocker struct {
|
||||
type RWLocker struct {
|
||||
once sync.Once
|
||||
mu RWLocker
|
||||
mu rwLocker
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) Synchronize() {
|
||||
if w.mu == nil || w.mu == EmptyLocker {
|
||||
log.Println("初始化有效锁")
|
||||
func (w *RWLocker) Synchronize() *RWLocker {
|
||||
if w.mu == nil || w.mu == empty {
|
||||
w.mu = NewRWLocker()
|
||||
}
|
||||
|
||||
return w
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) Lock() {
|
||||
w.ensureLocker().Lock()
|
||||
func (w *RWLocker) Lock() {
|
||||
w.ensureLocker().mu.Lock()
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) TryLock() bool {
|
||||
return w.ensureLocker().TryLock()
|
||||
func (w *RWLocker) TryLock() bool {
|
||||
return w.ensureLocker().mu.TryLock()
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) Unlock() {
|
||||
w.ensureLocker().Unlock()
|
||||
func (w *RWLocker) Unlock() {
|
||||
w.ensureLocker().mu.Unlock()
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) RLock() {
|
||||
w.ensureLocker().RLock()
|
||||
func (w *RWLocker) RLock() {
|
||||
w.ensureLocker().mu.RLock()
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) TryRLock() bool {
|
||||
return w.ensureLocker().TryRLock()
|
||||
func (w *RWLocker) TryRLock() bool {
|
||||
return w.ensureLocker().mu.TryRLock()
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) RUnlock() {
|
||||
w.ensureLocker().RUnlock()
|
||||
func (w *RWLocker) RUnlock() {
|
||||
w.ensureLocker().mu.RUnlock()
|
||||
}
|
||||
|
||||
func (w *WithRWLocker) ensureLocker() RWLocker {
|
||||
func (w *RWLocker) ensureLocker() *RWLocker {
|
||||
w.once.Do(func() {
|
||||
if w.mu == nil {
|
||||
log.Println("初始化一个空锁")
|
||||
w.mu = EmptyLocker
|
||||
w.mu = empty
|
||||
}
|
||||
})
|
||||
|
||||
return w.mu
|
||||
return w
|
||||
}
|
||||
|
44
locker/synchronizeable_test.go
Normal file
44
locker/synchronizeable_test.go
Normal file
@ -0,0 +1,44 @@
|
||||
package locker_test
|
||||
|
||||
import (
|
||||
"testing"
|
||||
|
||||
"github.com/charlienet/go-mixed/locker"
|
||||
)
|
||||
|
||||
func TestLocker(t *testing.T) {
|
||||
|
||||
var l locker.Locker
|
||||
|
||||
l.Synchronize()
|
||||
|
||||
l.Lock()
|
||||
defer l.Unlock()
|
||||
}
|
||||
|
||||
func TestNew(t *testing.T) {
|
||||
var a locker.RWLocker
|
||||
a.Synchronize()
|
||||
|
||||
}
|
||||
|
||||
func TestSpinLocker(t *testing.T) {
|
||||
var l locker.SpinLocker
|
||||
l.Synchronize()
|
||||
|
||||
l.Lock()
|
||||
defer l.Unlock()
|
||||
}
|
||||
|
||||
func TestRWLocker(t *testing.T) {
|
||||
var l locker.RWLocker
|
||||
l.Lock()
|
||||
}
|
||||
|
||||
func TestPointLocker(t *testing.T) {
|
||||
l := locker.NewLocker()
|
||||
l.Lock()
|
||||
l.Lock()
|
||||
|
||||
defer l.Unlock()
|
||||
}
|
Reference in New Issue
Block a user