mirror of
				https://github.com/minio/minio.git
				synced 2025-11-04 10:11:09 +01:00 
			
		
		
		
	Depending on when the context cancelation is picked up the handler may return and close the channel before `SubscribeJSON` returns, causing: ``` Feb 05 17:12:00 s3-us-node11 minio[3973657]: panic: send on closed channel Feb 05 17:12:00 s3-us-node11 minio[3973657]: goroutine 378007076 [running]: Feb 05 17:12:00 s3-us-node11 minio[3973657]: github.com/minio/minio/internal/pubsub.(*PubSub[...]).SubscribeJSON.func1() Feb 05 17:12:00 s3-us-node11 minio[3973657]: github.com/minio/minio/internal/pubsub/pubsub.go:139 +0x12d Feb 05 17:12:00 s3-us-node11 minio[3973657]: created by github.com/minio/minio/internal/pubsub.(*PubSub[...]).SubscribeJSON in goroutine 378010884 Feb 05 17:12:00 s3-us-node11 minio[3973657]: github.com/minio/minio/internal/pubsub/pubsub.go:124 +0x352 ``` Wait explicitly for the goroutine to exit. Bonus: Listen for doneCh when sending to not risk getting blocked there is channel isn't being emptied.
		
			
				
	
	
		
			197 lines
		
	
	
		
			5.2 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
			
		
		
	
	
			197 lines
		
	
	
		
			5.2 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
// Copyright (c) 2015-2024 MinIO, Inc.
 | 
						|
//
 | 
						|
// This file is part of MinIO Object Storage stack
 | 
						|
//
 | 
						|
// This program is free software: you can redistribute it and/or modify
 | 
						|
// it under the terms of the GNU Affero General Public License as published by
 | 
						|
// the Free Software Foundation, either version 3 of the License, or
 | 
						|
// (at your option) any later version.
 | 
						|
//
 | 
						|
// This program is distributed in the hope that it will be useful
 | 
						|
// but WITHOUT ANY WARRANTY; without even the implied warranty of
 | 
						|
// MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the
 | 
						|
// GNU Affero General Public License for more details.
 | 
						|
//
 | 
						|
// You should have received a copy of the GNU Affero General Public License
 | 
						|
// along with this program.  If not, see <http://www.gnu.org/licenses/>.
 | 
						|
 | 
						|
package pubsub
 | 
						|
 | 
						|
import (
 | 
						|
	"bytes"
 | 
						|
	"encoding/json"
 | 
						|
	"fmt"
 | 
						|
	"sync"
 | 
						|
	"sync/atomic"
 | 
						|
)
 | 
						|
 | 
						|
// GetByteBuffer returns a byte buffer from the pool.
 | 
						|
var GetByteBuffer = func() []byte {
 | 
						|
	return make([]byte, 0, 4096)
 | 
						|
}
 | 
						|
 | 
						|
// Sub - subscriber entity.
 | 
						|
type Sub[T Maskable] struct {
 | 
						|
	ch     chan T
 | 
						|
	types  Mask
 | 
						|
	filter func(entry T) bool
 | 
						|
}
 | 
						|
 | 
						|
// PubSub holds publishers and subscribers
 | 
						|
type PubSub[T Maskable, M Maskable] struct {
 | 
						|
	// atomics, keep at top:
 | 
						|
	types          uint64
 | 
						|
	numSubscribers int32
 | 
						|
	maxSubscribers int32
 | 
						|
 | 
						|
	// not atomics:
 | 
						|
	subs []*Sub[T]
 | 
						|
	sync.RWMutex
 | 
						|
}
 | 
						|
 | 
						|
// Publish message to the subscribers.
 | 
						|
// Note that publish is always non-blocking send so that we don't block on slow receivers.
 | 
						|
// Hence receivers should use buffered channel so as not to miss the published events.
 | 
						|
func (ps *PubSub[T, M]) Publish(item T) {
 | 
						|
	ps.RLock()
 | 
						|
	defer ps.RUnlock()
 | 
						|
	for _, sub := range ps.subs {
 | 
						|
		if sub.types.Contains(Mask(item.Mask())) && (sub.filter == nil || sub.filter(item)) {
 | 
						|
			select {
 | 
						|
			case sub.ch <- item:
 | 
						|
			default:
 | 
						|
			}
 | 
						|
		}
 | 
						|
	}
 | 
						|
}
 | 
						|
 | 
						|
// Subscribe - Adds a subscriber to pubsub system
 | 
						|
func (ps *PubSub[T, M]) Subscribe(mask M, subCh chan T, doneCh <-chan struct{}, filter func(entry T) bool) error {
 | 
						|
	totalSubs := atomic.AddInt32(&ps.numSubscribers, 1)
 | 
						|
	if ps.maxSubscribers > 0 && totalSubs > ps.maxSubscribers {
 | 
						|
		atomic.AddInt32(&ps.numSubscribers, -1)
 | 
						|
		return fmt.Errorf("the limit of `%d` subscribers is reached", ps.maxSubscribers)
 | 
						|
	}
 | 
						|
	ps.Lock()
 | 
						|
	defer ps.Unlock()
 | 
						|
 | 
						|
	sub := &Sub[T]{ch: subCh, types: Mask(mask.Mask()), filter: filter}
 | 
						|
	ps.subs = append(ps.subs, sub)
 | 
						|
 | 
						|
	// We hold a lock, so we are safe to update
 | 
						|
	combined := Mask(atomic.LoadUint64(&ps.types))
 | 
						|
	combined.Merge(Mask(mask.Mask()))
 | 
						|
	atomic.StoreUint64(&ps.types, uint64(combined))
 | 
						|
 | 
						|
	go func() {
 | 
						|
		<-doneCh
 | 
						|
 | 
						|
		ps.Lock()
 | 
						|
		defer ps.Unlock()
 | 
						|
		var remainTypes Mask
 | 
						|
		for i, s := range ps.subs {
 | 
						|
			if s == sub {
 | 
						|
				ps.subs = append(ps.subs[:i], ps.subs[i+1:]...)
 | 
						|
			} else {
 | 
						|
				remainTypes.Merge(s.types)
 | 
						|
			}
 | 
						|
		}
 | 
						|
		atomic.StoreUint64(&ps.types, uint64(remainTypes))
 | 
						|
		atomic.AddInt32(&ps.numSubscribers, -1)
 | 
						|
	}()
 | 
						|
 | 
						|
	return nil
 | 
						|
}
 | 
						|
 | 
						|
// SubscribeJSON - Adds a subscriber to pubsub system and returns results with JSON encoding.
 | 
						|
func (ps *PubSub[T, M]) SubscribeJSON(mask M, subCh chan<- []byte, doneCh <-chan struct{}, filter func(entry T) bool, wg *sync.WaitGroup) error {
 | 
						|
	totalSubs := atomic.AddInt32(&ps.numSubscribers, 1)
 | 
						|
	if ps.maxSubscribers > 0 && totalSubs > ps.maxSubscribers {
 | 
						|
		atomic.AddInt32(&ps.numSubscribers, -1)
 | 
						|
		return fmt.Errorf("the limit of `%d` subscribers is reached", ps.maxSubscribers)
 | 
						|
	}
 | 
						|
	ps.Lock()
 | 
						|
	defer ps.Unlock()
 | 
						|
	subChT := make(chan T, 10000)
 | 
						|
	sub := &Sub[T]{ch: subChT, types: Mask(mask.Mask()), filter: filter}
 | 
						|
	ps.subs = append(ps.subs, sub)
 | 
						|
 | 
						|
	// We hold a lock, so we are safe to update
 | 
						|
	combined := Mask(atomic.LoadUint64(&ps.types))
 | 
						|
	combined.Merge(Mask(mask.Mask()))
 | 
						|
	atomic.StoreUint64(&ps.types, uint64(combined))
 | 
						|
	if wg != nil {
 | 
						|
		wg.Add(1)
 | 
						|
	}
 | 
						|
	go func() {
 | 
						|
		defer func() {
 | 
						|
			if wg != nil {
 | 
						|
				wg.Done()
 | 
						|
			}
 | 
						|
			// Clean up and de-register the subscriber
 | 
						|
			ps.Lock()
 | 
						|
			defer ps.Unlock()
 | 
						|
			var remainTypes Mask
 | 
						|
			for i, s := range ps.subs {
 | 
						|
				if s == sub {
 | 
						|
					ps.subs = append(ps.subs[:i], ps.subs[i+1:]...)
 | 
						|
				} else {
 | 
						|
					remainTypes.Merge(s.types)
 | 
						|
				}
 | 
						|
			}
 | 
						|
			atomic.StoreUint64(&ps.types, uint64(remainTypes))
 | 
						|
			atomic.AddInt32(&ps.numSubscribers, -1)
 | 
						|
		}()
 | 
						|
 | 
						|
		// Read from subChT and write to subCh
 | 
						|
		var buf bytes.Buffer
 | 
						|
		enc := json.NewEncoder(&buf)
 | 
						|
		for {
 | 
						|
			select {
 | 
						|
			case <-doneCh:
 | 
						|
				return
 | 
						|
			case v, ok := <-subChT:
 | 
						|
				if !ok {
 | 
						|
					return
 | 
						|
				}
 | 
						|
				buf.Reset()
 | 
						|
				err := enc.Encode(v)
 | 
						|
				if err != nil {
 | 
						|
					return
 | 
						|
				}
 | 
						|
 | 
						|
				select {
 | 
						|
				case subCh <- append(GetByteBuffer()[:0], buf.Bytes()...):
 | 
						|
					continue
 | 
						|
				case <-doneCh:
 | 
						|
					return
 | 
						|
				}
 | 
						|
			}
 | 
						|
		}
 | 
						|
	}()
 | 
						|
 | 
						|
	return nil
 | 
						|
}
 | 
						|
 | 
						|
// NumSubscribers returns the number of current subscribers,
 | 
						|
// The mask is checked against the active subscribed types,
 | 
						|
// and 0 will be returned if nobody is subscribed for the type(s).
 | 
						|
func (ps *PubSub[T, M]) NumSubscribers(mask M) int32 {
 | 
						|
	types := Mask(atomic.LoadUint64(&ps.types))
 | 
						|
	if !types.Overlaps(Mask(mask.Mask())) {
 | 
						|
		return 0
 | 
						|
	}
 | 
						|
	return atomic.LoadInt32(&ps.numSubscribers)
 | 
						|
}
 | 
						|
 | 
						|
// Subscribers returns the number of current subscribers for all types.
 | 
						|
func (ps *PubSub[T, M]) Subscribers() int32 {
 | 
						|
	return atomic.LoadInt32(&ps.numSubscribers)
 | 
						|
}
 | 
						|
 | 
						|
// New inits a PubSub system with a limit of maximum
 | 
						|
// subscribers unless zero is specified
 | 
						|
func New[T Maskable, M Maskable](maxSubscribers int32) *PubSub[T, M] {
 | 
						|
	return &PubSub[T, M]{maxSubscribers: maxSubscribers}
 | 
						|
}
 |