1
0
mirror of https://github.com/v2fly/v2ray-core.git synced 2024-06-30 19:15:23 +00:00

switch to pubsub in dns service

This commit is contained in:
Darien Raymond 2018-07-01 12:38:40 +02:00
parent 596d05bff5
commit 4368edf87c
No known key found for this signature in database
GPG Key ID: 7251FFA14BB18169
6 changed files with 154 additions and 38 deletions

View File

@ -11,7 +11,7 @@ import (
"v2ray.com/core/common" "v2ray.com/core/common"
"v2ray.com/core/common/buf" "v2ray.com/core/common/buf"
"v2ray.com/core/common/net" "v2ray.com/core/common/net"
"v2ray.com/core/common/signal" "v2ray.com/core/common/signal/pubsub"
"v2ray.com/core/common/task" "v2ray.com/core/common/task"
"v2ray.com/core/transport/internet/udp" "v2ray.com/core/transport/internet/udp"
) )
@ -33,7 +33,7 @@ type ClassicNameServer struct {
sync.RWMutex sync.RWMutex
address net.Destination address net.Destination
ips map[string][]IPRecord ips map[string][]IPRecord
updated signal.Notifier pub *pubsub.Service
udpServer *udp.Dispatcher udpServer *udp.Dispatcher
cleanup *task.Periodic cleanup *task.Periodic
reqID uint32 reqID uint32
@ -46,6 +46,7 @@ func NewClassicNameServer(address net.Destination, dispatcher core.Dispatcher, c
ips: make(map[string][]IPRecord), ips: make(map[string][]IPRecord),
udpServer: udp.NewDispatcher(dispatcher), udpServer: udp.NewDispatcher(dispatcher),
clientIP: clientIP, clientIP: clientIP,
pub: pubsub.NewService(),
} }
s.cleanup = &task.Periodic{ s.cleanup = &task.Periodic{
Interval: time.Minute, Interval: time.Minute,
@ -96,7 +97,10 @@ func (s *ClassicNameServer) HandleResponse(payload *buf.Buffer) {
now := time.Now() now := time.Now()
for _, rr := range msg.Answer { for _, rr := range msg.Answer {
var ip net.IP var ip net.IP
domain = rr.Header().Name name := rr.Header().Name
if len(name) > 0 {
domain = rr.Header().Name
}
ttl := rr.Header().Ttl ttl := rr.Header().Ttl
switch rr := rr.(type) { switch rr := rr.(type) {
case *dns.A: case *dns.A:
@ -105,7 +109,7 @@ func (s *ClassicNameServer) HandleResponse(payload *buf.Buffer) {
ip = rr.AAAA ip = rr.AAAA
} }
if ttl == 0 { if ttl == 0 {
ttl = 300 ttl = 600
} }
if len(ip) > 0 { if len(ip) > 0 {
ips = append(ips, IPRecord{ ips = append(ips, IPRecord{
@ -133,7 +137,7 @@ func (s *ClassicNameServer) updateIP(domain string, ips []IPRecord) {
} }
} }
s.ips[domain] = ips s.ips[domain] = ips
s.updated.Signal() s.pub.Publish(domain, nil)
} }
func (s *ClassicNameServer) getMsgOptions() *dns.OPT { func (s *ClassicNameServer) getMsgOptions() *dns.OPT {
@ -255,6 +259,9 @@ func (s *ClassicNameServer) QueryIP(ctx context.Context, domain string) ([]net.I
return ips, nil return ips, nil
} }
sub := s.pub.Subscribe(fqdn)
defer sub.Close()
s.sendQuery(ctx, fqdn) s.sendQuery(ctx, fqdn)
for { for {
@ -266,7 +273,7 @@ func (s *ClassicNameServer) QueryIP(ctx context.Context, domain string) ([]net.I
select { select {
case <-ctx.Done(): case <-ctx.Done():
return nil, ctx.Err() return nil, ctx.Err()
case <-s.updated.Wait(): case <-sub.Wait():
} }
} }
} }

View File

@ -1,47 +1,26 @@
package signal package signal
import "sync"
// Notifier is a utility for notifying changes. The change producer may notify changes multiple time, and the consumer may get notified asynchronously. // Notifier is a utility for notifying changes. The change producer may notify changes multiple time, and the consumer may get notified asynchronously.
type Notifier struct { type Notifier struct {
sync.Mutex c chan struct{}
waiters []chan struct{}
notCosumed bool
} }
// NewNotifier creates a new Notifier. // NewNotifier creates a new Notifier.
func NewNotifier() *Notifier { func NewNotifier() *Notifier {
return &Notifier{} return &Notifier{
c: make(chan struct{}, 1),
}
} }
// Signal signals a change, usually by producer. This method never blocks. // Signal signals a change, usually by producer. This method never blocks.
func (n *Notifier) Signal() { func (n *Notifier) Signal() {
n.Lock() select {
defer n.Unlock() case n.c <- struct{}{}:
default:
if len(n.waiters) == 0 {
n.notCosumed = true
return
} }
for _, w := range n.waiters {
close(w)
}
n.waiters = make([]chan struct{}, 0, 8)
} }
// Wait returns a channel for waiting for changes. // Wait returns a channel for waiting for changes. The returned channel never gets closed.
func (n *Notifier) Wait() <-chan struct{} { func (n *Notifier) Wait() <-chan struct{} {
n.Lock() return n.c
defer n.Unlock()
w := make(chan struct{})
if n.notCosumed {
n.notCosumed = false
close(w)
return w
}
n.waiters = append(n.waiters, w)
return w
} }

View File

@ -10,7 +10,7 @@ import (
func TestNotifierSignal(t *testing.T) { func TestNotifierSignal(t *testing.T) {
//assert := With(t) //assert := With(t)
var n Notifier n := NewNotifier()
w := n.Wait() w := n.Wait()
n.Signal() n.Signal()

View File

@ -0,0 +1,97 @@
package pubsub
import (
"sync"
"time"
"v2ray.com/core/common"
"v2ray.com/core/common/task"
)
type Subscriber struct {
name string
buffer chan interface{}
removed chan struct{}
}
func (s *Subscriber) push(msg interface{}) {
select {
case s.buffer <- msg:
default:
}
}
func (s *Subscriber) Wait() <-chan interface{} {
return s.buffer
}
func (s *Subscriber) Close() {
close(s.removed)
}
func (s *Subscriber) IsClosed() bool {
select {
case <-s.removed:
return true
default:
return false
}
}
type Service struct {
sync.RWMutex
subs []*Subscriber
ctask *task.Periodic
}
func NewService() *Service {
s := &Service{}
s.ctask = &task.Periodic{
Execute: s.cleanup,
Interval: time.Second * 30,
}
common.Must(s.ctask.Start())
return s
}
func (s *Service) cleanup() error {
s.Lock()
defer s.Unlock()
if len(s.subs) < 16 {
return nil
}
newSub := make([]*Subscriber, 0, len(s.subs))
for _, sub := range s.subs {
if !sub.IsClosed() {
newSub = append(newSub, sub)
}
}
s.subs = newSub
return nil
}
func (s *Service) Subscribe(name string) *Subscriber {
sub := &Subscriber{
name: name,
buffer: make(chan interface{}, 16),
removed: make(chan struct{}),
}
s.Lock()
s.subs = append(s.subs, sub)
s.Unlock()
return sub
}
func (s *Service) Publish(name string, message interface{}) {
s.RLock()
defer s.RUnlock()
for _, sub := range s.subs {
if sub.name == name && !sub.IsClosed() {
sub.push(message)
}
}
}

View File

@ -0,0 +1,33 @@
package pubsub_test
import (
"testing"
. "v2ray.com/core/common/signal/pubsub"
. "v2ray.com/ext/assert"
)
func TestPubsub(t *testing.T) {
assert := With(t)
service := NewService()
sub := service.Subscribe("a")
service.Publish("a", 1)
select {
case v := <-sub.Wait():
assert(v.(int), Equals, 1)
default:
t.Fail()
}
sub.Close()
service.Publish("a", 2)
select {
case <-sub.Wait():
t.Fail()
default:
}
}

View File

@ -62,7 +62,7 @@ func (v *Handler) Process(ctx context.Context, link *core.Link, dialer proxy.Dia
if err != nil { if err != nil {
return newError("failed to find an available destination").Base(err).AtWarning() return newError("failed to find an available destination").Base(err).AtWarning()
} }
defer conn.Close() defer conn.Close() //nolint: errcheck
target, ok := proxy.TargetFromContext(ctx) target, ok := proxy.TargetFromContext(ctx)
if !ok { if !ok {