mirror of
				https://github.com/tailscale/tailscale.git
				synced 2025-10-26 05:41:04 +01:00 
			
		
		
		
	util/eventbus: add a function-based subscriber type (#17432)
Originally proposed by @bradfitz in #17413. In practice, a lot of subscribers have only one event type of interest, or a small number of mostly independent ones. In that case, the overhead of running and maintaining a goroutine to select on multiple channels winds up being more noisy than we'd like for the user of the API. For this common case, add a new SubscriberFunc[T] type that delivers events to a callback owned by the subscriber, directly on the goroutine belonging to the client itself. This frees the consumer from the need to maintain their own goroutine to pull events from the channel, and to watch for closure of the subscriber. Before: s := eventbus.Subscribe[T](eventClient) go func() { for { select { case <-s.Done(): return case e := <-s.Events(): doSomethingWith(e) } } }() // ... s.Close() After: func doSomethingWithT(e T) { ... } s := eventbus.SubscribeFunc(eventClient, doSomethingWithT) // ... s.Close() Moreover, unless the caller wants to explicitly stop the subscriber separately from its governing client, it need not capture the SubscriberFunc value at all. One downside of this approach is that a slow or deadlocked callback could block client's service routine and thus stall all other subscriptions on that client, However, this can already happen more broadly if a subscriber fails to service its delivery channel in a timely manner, it just feeds back more immediately. Updates #17487 Change-Id: I64592d786005177aa9fd445c263178ed415784d5 Signed-off-by: M. J. Fromberger <fromberger@tailscale.com>
This commit is contained in:
		
							parent
							
								
									98a0ccc18a
								
							
						
					
					
						commit
						ad6cf2f8f3
					
				| @ -7,6 +7,7 @@ import ( | |||||||
| 	"errors" | 	"errors" | ||||||
| 	"fmt" | 	"fmt" | ||||||
| 	"testing" | 	"testing" | ||||||
|  | 	"testing/synctest" | ||||||
| 	"time" | 	"time" | ||||||
| 
 | 
 | ||||||
| 	"github.com/creachadair/taskgroup" | 	"github.com/creachadair/taskgroup" | ||||||
| @ -64,6 +65,55 @@ func TestBus(t *testing.T) { | |||||||
| 	} | 	} | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
|  | func TestSubscriberFunc(t *testing.T) { | ||||||
|  | 	synctest.Test(t, func(t *testing.T) { | ||||||
|  | 		b := eventbus.New() | ||||||
|  | 		defer b.Close() | ||||||
|  | 
 | ||||||
|  | 		c := b.Client("TestClient") | ||||||
|  | 
 | ||||||
|  | 		exp := expectEvents(t, EventA{12345}) | ||||||
|  | 		eventbus.SubscribeFunc[EventA](c, func(e EventA) { exp.Got(e) }) | ||||||
|  | 
 | ||||||
|  | 		p := eventbus.Publish[EventA](c) | ||||||
|  | 		p.Publish(EventA{12345}) | ||||||
|  | 
 | ||||||
|  | 		synctest.Wait() | ||||||
|  | 		c.Close() | ||||||
|  | 
 | ||||||
|  | 		if !exp.Empty() { | ||||||
|  | 			t.Errorf("unexpected extra events: %+v", exp.want) | ||||||
|  | 		} | ||||||
|  | 	}) | ||||||
|  | 
 | ||||||
|  | 	t.Run("SubscriberPublishes", func(t *testing.T) { | ||||||
|  | 		synctest.Test(t, func(t *testing.T) { | ||||||
|  | 			b := eventbus.New() | ||||||
|  | 			defer b.Close() | ||||||
|  | 
 | ||||||
|  | 			c := b.Client("TestClient") | ||||||
|  | 			pa := eventbus.Publish[EventA](c) | ||||||
|  | 			pb := eventbus.Publish[EventB](c) | ||||||
|  | 			exp := expectEvents(t, EventA{127}, EventB{128}) | ||||||
|  | 			eventbus.SubscribeFunc[EventA](c, func(e EventA) { | ||||||
|  | 				exp.Got(e) | ||||||
|  | 				pb.Publish(EventB{Counter: e.Counter + 1}) | ||||||
|  | 			}) | ||||||
|  | 			eventbus.SubscribeFunc[EventB](c, func(e EventB) { | ||||||
|  | 				exp.Got(e) | ||||||
|  | 			}) | ||||||
|  | 
 | ||||||
|  | 			pa.Publish(EventA{127}) | ||||||
|  | 
 | ||||||
|  | 			synctest.Wait() | ||||||
|  | 			c.Close() | ||||||
|  | 			if !exp.Empty() { | ||||||
|  | 				t.Errorf("unepxected extra events: %+v", exp.want) | ||||||
|  | 			} | ||||||
|  | 		}) | ||||||
|  | 	}) | ||||||
|  | } | ||||||
|  | 
 | ||||||
| func TestBusMultipleConsumers(t *testing.T) { | func TestBusMultipleConsumers(t *testing.T) { | ||||||
| 	b := eventbus.New() | 	b := eventbus.New() | ||||||
| 	defer b.Close() | 	defer b.Close() | ||||||
| @ -111,80 +161,149 @@ func TestBusMultipleConsumers(t *testing.T) { | |||||||
| 	} | 	} | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| func TestSpam(t *testing.T) { | func TestClientMixedSubscribers(t *testing.T) { | ||||||
| 	b := eventbus.New() | 	synctest.Test(t, func(t *testing.T) { | ||||||
| 	defer b.Close() | 		b := eventbus.New() | ||||||
|  | 		defer b.Close() | ||||||
| 
 | 
 | ||||||
| 	const ( | 		c := b.Client("TestClient") | ||||||
| 		publishers         = 100 |  | ||||||
| 		eventsPerPublisher = 20 |  | ||||||
| 		wantEvents         = publishers * eventsPerPublisher |  | ||||||
| 		subscribers        = 100 |  | ||||||
| 	) |  | ||||||
| 
 | 
 | ||||||
| 	var g taskgroup.Group | 		var gotA EventA | ||||||
|  | 		s1 := eventbus.Subscribe[EventA](c) | ||||||
| 
 | 
 | ||||||
| 	received := make([][]EventA, subscribers) | 		var gotB EventB | ||||||
| 	for i := range subscribers { | 		eventbus.SubscribeFunc[EventB](c, func(e EventB) { | ||||||
| 		c := b.Client(fmt.Sprintf("Subscriber%d", i)) | 			t.Logf("func sub received %[1]T %+[1]v", e) | ||||||
| 		defer c.Close() | 			gotB = e | ||||||
| 		s := eventbus.Subscribe[EventA](c) | 		}) | ||||||
| 		g.Go(func() error { | 
 | ||||||
| 			for range wantEvents { | 		go func() { | ||||||
|  | 			for { | ||||||
| 				select { | 				select { | ||||||
| 				case evt := <-s.Events(): | 				case <-s1.Done(): | ||||||
| 					received[i] = append(received[i], evt) | 					return | ||||||
| 				case <-s.Done(): | 				case e := <-s1.Events(): | ||||||
| 					t.Errorf("queue done before expected number of events received") | 					t.Logf("chan sub received %[1]T %+[1]v", e) | ||||||
| 					return errors.New("queue prematurely closed") | 					gotA = e | ||||||
| 				case <-time.After(5 * time.Second): |  | ||||||
| 					t.Errorf("timed out waiting for expected bus event after %d events", len(received[i])) |  | ||||||
| 					return errors.New("timeout") |  | ||||||
| 				} | 				} | ||||||
| 			} | 			} | ||||||
| 			return nil | 		}() | ||||||
| 		}) |  | ||||||
| 	} |  | ||||||
| 
 | 
 | ||||||
| 	published := make([][]EventA, publishers) | 		p1 := eventbus.Publish[EventA](c) | ||||||
| 	for i := range publishers { | 		p2 := eventbus.Publish[EventB](c) | ||||||
| 		g.Run(func() { | 
 | ||||||
|  | 		go p1.Publish(EventA{12345}) | ||||||
|  | 		go p2.Publish(EventB{67890}) | ||||||
|  | 
 | ||||||
|  | 		synctest.Wait() | ||||||
|  | 		c.Close() | ||||||
|  | 		synctest.Wait() | ||||||
|  | 
 | ||||||
|  | 		if diff := cmp.Diff(gotB, EventB{67890}); diff != "" { | ||||||
|  | 			t.Errorf("Chan sub (-got, +want):\n%s", diff) | ||||||
|  | 		} | ||||||
|  | 		if diff := cmp.Diff(gotA, EventA{12345}); diff != "" { | ||||||
|  | 			t.Errorf("Func sub (-got, +want):\n%s", diff) | ||||||
|  | 		} | ||||||
|  | 	}) | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | func TestSpam(t *testing.T) { | ||||||
|  | 	synctest.Test(t, func(t *testing.T) { | ||||||
|  | 		b := eventbus.New() | ||||||
|  | 		defer b.Close() | ||||||
|  | 
 | ||||||
|  | 		const ( | ||||||
|  | 			publishers         = 100 | ||||||
|  | 			eventsPerPublisher = 20 | ||||||
|  | 			wantEvents         = publishers * eventsPerPublisher | ||||||
|  | 			subscribers        = 100 | ||||||
|  | 		) | ||||||
|  | 
 | ||||||
|  | 		var g taskgroup.Group | ||||||
|  | 
 | ||||||
|  | 		// A bunch of subscribers receiving on channels. | ||||||
|  | 		chanReceived := make([][]EventA, subscribers) | ||||||
|  | 		for i := range subscribers { | ||||||
|  | 			c := b.Client(fmt.Sprintf("Subscriber%d", i)) | ||||||
|  | 			defer c.Close() | ||||||
|  | 
 | ||||||
|  | 			s := eventbus.Subscribe[EventA](c) | ||||||
|  | 			g.Go(func() error { | ||||||
|  | 				for range wantEvents { | ||||||
|  | 					select { | ||||||
|  | 					case evt := <-s.Events(): | ||||||
|  | 						chanReceived[i] = append(chanReceived[i], evt) | ||||||
|  | 					case <-s.Done(): | ||||||
|  | 						t.Errorf("queue done before expected number of events received") | ||||||
|  | 						return errors.New("queue prematurely closed") | ||||||
|  | 					case <-time.After(5 * time.Second): | ||||||
|  | 						t.Logf("timed out waiting for expected bus event after %d events", len(chanReceived[i])) | ||||||
|  | 						return errors.New("timeout") | ||||||
|  | 					} | ||||||
|  | 				} | ||||||
|  | 				return nil | ||||||
|  | 			}) | ||||||
|  | 		} | ||||||
|  | 
 | ||||||
|  | 		// A bunch of subscribers receiving via a func. | ||||||
|  | 		funcReceived := make([][]EventA, subscribers) | ||||||
|  | 		for i := range subscribers { | ||||||
|  | 			c := b.Client(fmt.Sprintf("SubscriberFunc%d", i)) | ||||||
|  | 			defer c.Close() | ||||||
|  | 			eventbus.SubscribeFunc(c, func(e EventA) { | ||||||
|  | 				funcReceived[i] = append(funcReceived[i], e) | ||||||
|  | 			}) | ||||||
|  | 		} | ||||||
|  | 
 | ||||||
|  | 		published := make([][]EventA, publishers) | ||||||
|  | 		for i := range publishers { | ||||||
| 			c := b.Client(fmt.Sprintf("Publisher%d", i)) | 			c := b.Client(fmt.Sprintf("Publisher%d", i)) | ||||||
| 			p := eventbus.Publish[EventA](c) | 			p := eventbus.Publish[EventA](c) | ||||||
| 			for j := range eventsPerPublisher { | 			g.Run(func() { | ||||||
| 				evt := EventA{i*eventsPerPublisher + j} | 				defer c.Close() | ||||||
| 				p.Publish(evt) | 				for j := range eventsPerPublisher { | ||||||
| 				published[i] = append(published[i], evt) | 					evt := EventA{i*eventsPerPublisher + j} | ||||||
|  | 					p.Publish(evt) | ||||||
|  | 					published[i] = append(published[i], evt) | ||||||
|  | 				} | ||||||
|  | 			}) | ||||||
|  | 		} | ||||||
|  | 
 | ||||||
|  | 		if err := g.Wait(); err != nil { | ||||||
|  | 			t.Fatal(err) | ||||||
|  | 		} | ||||||
|  | 		synctest.Wait() | ||||||
|  | 
 | ||||||
|  | 		tests := []struct { | ||||||
|  | 			name string | ||||||
|  | 			recv [][]EventA | ||||||
|  | 		}{ | ||||||
|  | 			{"Subscriber", chanReceived}, | ||||||
|  | 			{"SubscriberFunc", funcReceived}, | ||||||
|  | 		} | ||||||
|  | 		for _, tc := range tests { | ||||||
|  | 			for i, got := range tc.recv { | ||||||
|  | 				if len(got) != wantEvents { | ||||||
|  | 					t.Errorf("%s %d: got %d events, want %d", tc.name, i, len(got), wantEvents) | ||||||
|  | 				} | ||||||
|  | 				if i == 0 { | ||||||
|  | 					continue | ||||||
|  | 				} | ||||||
|  | 				if diff := cmp.Diff(got, tc.recv[i-1]); diff != "" { | ||||||
|  | 					t.Errorf("%s %d did not see the same events as %d (-got+want):\n%s", tc.name, i, i-1, diff) | ||||||
|  | 				} | ||||||
| 			} | 			} | ||||||
| 		}) | 		} | ||||||
| 	} | 		for i, sent := range published { | ||||||
|  | 			if got := len(sent); got != eventsPerPublisher { | ||||||
|  | 				t.Fatalf("Publisher %d sent %d events, want %d", i, got, eventsPerPublisher) | ||||||
|  | 			} | ||||||
|  | 		} | ||||||
| 
 | 
 | ||||||
| 	if err := g.Wait(); err != nil { | 		// TODO: check that the published sequences are proper | ||||||
| 		t.Fatal(err) | 		// subsequences of the received slices. | ||||||
| 	} | 	}) | ||||||
| 	var last []EventA |  | ||||||
| 	for i, got := range received { |  | ||||||
| 		if len(got) != wantEvents { |  | ||||||
| 			// Receiving goroutine already reported an error, we just need |  | ||||||
| 			// to fail early within the main test goroutine. |  | ||||||
| 			t.FailNow() |  | ||||||
| 		} |  | ||||||
| 		if last == nil { |  | ||||||
| 			continue |  | ||||||
| 		} |  | ||||||
| 		if diff := cmp.Diff(got, last); diff != "" { |  | ||||||
| 			t.Errorf("Subscriber %d did not see the same events as %d (-got+want):\n%s", i, i-1, diff) |  | ||||||
| 		} |  | ||||||
| 		last = got |  | ||||||
| 	} |  | ||||||
| 	for i, sent := range published { |  | ||||||
| 		if got := len(sent); got != eventsPerPublisher { |  | ||||||
| 			t.Fatalf("Publisher %d sent %d events, want %d", i, got, eventsPerPublisher) |  | ||||||
| 		} |  | ||||||
| 	} |  | ||||||
| 
 |  | ||||||
| 	// TODO: check that the published sequences are proper |  | ||||||
| 	// subsequences of the received slices. |  | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| func TestClient_Done(t *testing.T) { | func TestClient_Done(t *testing.T) { | ||||||
| @ -366,10 +485,12 @@ func expectEvents(t *testing.T, want ...any) *queueChecker { | |||||||
| func (q *queueChecker) Got(v any) { | func (q *queueChecker) Got(v any) { | ||||||
| 	q.t.Helper() | 	q.t.Helper() | ||||||
| 	if q.Empty() { | 	if q.Empty() { | ||||||
| 		q.t.Fatalf("queue got unexpected %v", v) | 		q.t.Errorf("queue got unexpected %v", v) | ||||||
|  | 		return | ||||||
| 	} | 	} | ||||||
| 	if v != q.want[0] { | 	if v != q.want[0] { | ||||||
| 		q.t.Fatalf("queue got %#v, want %#v", v, q.want[0]) | 		q.t.Errorf("queue got %#v, want %#v", v, q.want[0]) | ||||||
|  | 		return | ||||||
| 	} | 	} | ||||||
| 	q.want = q.want[1:] | 	q.want = q.want[1:] | ||||||
| } | } | ||||||
|  | |||||||
| @ -147,6 +147,29 @@ func Subscribe[T any](c *Client) *Subscriber[T] { | |||||||
| 	return s | 	return s | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
|  | // SubscribeFunc is like [Subscribe], but calls the provided func for each | ||||||
|  | // event of type T. | ||||||
|  | // | ||||||
|  | // A SubscriberFunc calls f synchronously from the client's goroutine. | ||||||
|  | // This means the callback must not block for an extended period of time, | ||||||
|  | // as this will block the subscriber and slow event processing for all | ||||||
|  | // subscriptions on c. | ||||||
|  | func SubscribeFunc[T any](c *Client, f func(T)) *SubscriberFunc[T] { | ||||||
|  | 	c.mu.Lock() | ||||||
|  | 	defer c.mu.Unlock() | ||||||
|  | 
 | ||||||
|  | 	// The caller should not race subscriptions with close, give them a useful | ||||||
|  | 	// diagnostic at the call site. | ||||||
|  | 	if c.isClosed() { | ||||||
|  | 		panic("cannot SubscribeFunc on a closed client") | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	r := c.subscribeStateLocked() | ||||||
|  | 	s := newSubscriberFunc[T](r, f) | ||||||
|  | 	r.addSubscriber(s) | ||||||
|  | 	return s | ||||||
|  | } | ||||||
|  | 
 | ||||||
| // Publish returns a publisher for event type T using the given client. | // Publish returns a publisher for event type T using the given client. | ||||||
| // It panics if c is closed. | // It panics if c is closed. | ||||||
| func Publish[T any](c *Client) *Publisher[T] { | func Publish[T any](c *Client) *Publisher[T] { | ||||||
|  | |||||||
| @ -61,45 +61,45 @@ func newSubscribeState(c *Client) *subscribeState { | |||||||
| 	return ret | 	return ret | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| func (q *subscribeState) pump(ctx context.Context) { | func (s *subscribeState) pump(ctx context.Context) { | ||||||
| 	var vals queue[DeliveredEvent] | 	var vals queue[DeliveredEvent] | ||||||
| 	acceptCh := func() chan DeliveredEvent { | 	acceptCh := func() chan DeliveredEvent { | ||||||
| 		if vals.Full() { | 		if vals.Full() { | ||||||
| 			return nil | 			return nil | ||||||
| 		} | 		} | ||||||
| 		return q.write | 		return s.write | ||||||
| 	} | 	} | ||||||
| 	for { | 	for { | ||||||
| 		if !vals.Empty() { | 		if !vals.Empty() { | ||||||
| 			val := vals.Peek() | 			val := vals.Peek() | ||||||
| 			sub := q.subscriberFor(val.Event) | 			sub := s.subscriberFor(val.Event) | ||||||
| 			if sub == nil { | 			if sub == nil { | ||||||
| 				// Raced with unsubscribe. | 				// Raced with unsubscribe. | ||||||
| 				vals.Drop() | 				vals.Drop() | ||||||
| 				continue | 				continue | ||||||
| 			} | 			} | ||||||
| 			if !sub.dispatch(ctx, &vals, acceptCh, q.snapshot) { | 			if !sub.dispatch(ctx, &vals, acceptCh, s.snapshot) { | ||||||
| 				return | 				return | ||||||
| 			} | 			} | ||||||
| 
 | 
 | ||||||
| 			if q.debug.active() { | 			if s.debug.active() { | ||||||
| 				q.debug.run(DeliveredEvent{ | 				s.debug.run(DeliveredEvent{ | ||||||
| 					Event: val.Event, | 					Event: val.Event, | ||||||
| 					From:  val.From, | 					From:  val.From, | ||||||
| 					To:    q.client, | 					To:    s.client, | ||||||
| 				}) | 				}) | ||||||
| 			} | 			} | ||||||
| 		} else { | 		} else { | ||||||
| 			// Keep the cases in this select in sync with | 			// Keep the cases in this select in sync with | ||||||
| 			// Subscriber.dispatch below. The only difference should be | 			// Subscriber.dispatch and SubscriberFunc.dispatch below. | ||||||
| 			// that this select doesn't deliver queued values to | 			// The only difference should be that this select doesn't deliver | ||||||
| 			// anyone, and unconditionally accepts new values. | 			// queued values to anyone, and unconditionally accepts new values. | ||||||
| 			select { | 			select { | ||||||
| 			case val := <-q.write: | 			case val := <-s.write: | ||||||
| 				vals.Add(val) | 				vals.Add(val) | ||||||
| 			case <-ctx.Done(): | 			case <-ctx.Done(): | ||||||
| 				return | 				return | ||||||
| 			case ch := <-q.snapshot: | 			case ch := <-s.snapshot: | ||||||
| 				ch <- vals.Snapshot() | 				ch <- vals.Snapshot() | ||||||
| 			} | 			} | ||||||
| 		} | 		} | ||||||
| @ -152,10 +152,10 @@ func (s *subscribeState) deleteSubscriber(t reflect.Type) { | |||||||
| 	s.client.deleteSubscriber(t, s) | 	s.client.deleteSubscriber(t, s) | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| func (q *subscribeState) subscriberFor(val any) subscriber { | func (s *subscribeState) subscriberFor(val any) subscriber { | ||||||
| 	q.outputsMu.Lock() | 	s.outputsMu.Lock() | ||||||
| 	defer q.outputsMu.Unlock() | 	defer s.outputsMu.Unlock() | ||||||
| 	return q.outputs[reflect.TypeOf(val)] | 	return s.outputs[reflect.TypeOf(val)] | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| // Close closes the subscribeState. It implicitly closes all Subscribers | // Close closes the subscribeState. It implicitly closes all Subscribers | ||||||
| @ -177,6 +177,7 @@ func (s *subscribeState) closed() <-chan struct{} { | |||||||
| } | } | ||||||
| 
 | 
 | ||||||
| // A Subscriber delivers one type of event from a [Client]. | // A Subscriber delivers one type of event from a [Client]. | ||||||
|  | // Events are sent to the [Subscriber.Events] channel. | ||||||
| type Subscriber[T any] struct { | type Subscriber[T any] struct { | ||||||
| 	stop       stopFlag | 	stop       stopFlag | ||||||
| 	read       chan T | 	read       chan T | ||||||
| @ -252,3 +253,49 @@ func (s *Subscriber[T]) Close() { | |||||||
| 	s.stop.Stop() // unblock receivers | 	s.stop.Stop() // unblock receivers | ||||||
| 	s.unregister() | 	s.unregister() | ||||||
| } | } | ||||||
|  | 
 | ||||||
|  | // A SubscriberFunc delivers one type of event from a [Client]. | ||||||
|  | // Events are forwarded synchronously to a function provided at construction. | ||||||
|  | type SubscriberFunc[T any] struct { | ||||||
|  | 	stop       stopFlag | ||||||
|  | 	read       func(T) | ||||||
|  | 	unregister func() | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | func newSubscriberFunc[T any](r *subscribeState, f func(T)) *SubscriberFunc[T] { | ||||||
|  | 	return &SubscriberFunc[T]{ | ||||||
|  | 		read:       f, | ||||||
|  | 		unregister: func() { r.deleteSubscriber(reflect.TypeFor[T]()) }, | ||||||
|  | 	} | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | // Close closes the SubscriberFunc, indicating the caller no longer wishes to | ||||||
|  | // receive this event type.  After Close, no further events will be passed to | ||||||
|  | // the callback. | ||||||
|  | // | ||||||
|  | // If the [Bus] from which s was created is closed, s is implicitly closed and | ||||||
|  | // does not need to be closed separately. | ||||||
|  | func (s *SubscriberFunc[T]) Close() { s.stop.Stop(); s.unregister() } | ||||||
|  | 
 | ||||||
|  | // subscribeType implements part of the subscriber interface. | ||||||
|  | func (s *SubscriberFunc[T]) subscribeType() reflect.Type { return reflect.TypeFor[T]() } | ||||||
|  | 
 | ||||||
|  | // dispatch implements part of the subscriber interface. | ||||||
|  | func (s *SubscriberFunc[T]) dispatch(ctx context.Context, vals *queue[DeliveredEvent], acceptCh func() chan DeliveredEvent, snapshot chan chan []DeliveredEvent) bool { | ||||||
|  | 	// Keep the cases in this select in sync with subscribeState.pump | ||||||
|  | 	// above. The only different should be that this select | ||||||
|  | 	// delivers a value by calling s.read. | ||||||
|  | 	select { | ||||||
|  | 	case val := <-acceptCh(): | ||||||
|  | 		vals.Add(val) | ||||||
|  | 	case <-ctx.Done(): | ||||||
|  | 		return false | ||||||
|  | 	case ch := <-snapshot: | ||||||
|  | 		ch <- vals.Snapshot() | ||||||
|  | 	default: | ||||||
|  | 	} | ||||||
|  | 	t := vals.Peek().Event.(T) | ||||||
|  | 	s.read(t) | ||||||
|  | 	vals.Drop() | ||||||
|  | 	return true | ||||||
|  | } | ||||||
|  | |||||||
		Loading…
	
	
			
			x
			
			
		
	
		Reference in New Issue
	
	Block a user