arikawa/utils/handler/handler.go

330 lines
8.0 KiB
Go
Raw Normal View History

// Package handler handles incoming Gateway events. It reflects the function's
// first argument and caches that for use in each event.
//
// # Performance
//
// Each call to the event would take 167 ns/op for roughly each handler. Scaling
// that up to 100 handlers is roughly the same as multiplying 167 ns by 100,
// which gives 16700 ns or 0.0167 ms.
//
// BenchmarkReflect-8 7260909 167 ns/op
//
// # Usage
//
// Handler's usage is mostly similar to Discordgo, in that AddHandler expects a
// function with only one argument or an event channel. For more information,
// refer to AddHandler.
2020-01-17 05:17:46 +00:00
package handler
import (
"context"
"errors"
2020-01-17 05:17:46 +00:00
"fmt"
"reflect"
"sync"
)
// Handler is a container for command handlers. A zero-value instance is a valid
// instance.
2020-01-17 05:17:46 +00:00
type Handler struct {
mutex sync.RWMutex
events map[reflect.Type]slab // nil type for interfaces
2020-01-17 05:17:46 +00:00
}
func New() *Handler {
return &Handler{}
2020-01-17 05:17:46 +00:00
}
// Call calls all handlers with the given event. This is an internal method; use
// with care.
2020-01-17 05:17:46 +00:00
func (h *Handler) Call(ev interface{}) {
2022-04-01 11:41:22 +00:00
t := reflect.TypeOf(ev)
2020-01-17 05:17:46 +00:00
h.mutex.RLock()
defer h.mutex.RUnlock()
2020-01-17 05:17:46 +00:00
2022-04-01 11:41:22 +00:00
typedHandlers := h.events[t].Entries
anyHandlers := h.events[nil].Entries
if len(typedHandlers) == 0 && len(anyHandlers) == 0 {
return
}
v := reflect.ValueOf(ev)
for _, entry := range typedHandlers {
if entry.isInvalid() {
2020-01-17 05:17:46 +00:00
continue
}
entry.Call(v)
}
2020-01-17 05:17:46 +00:00
2022-04-01 11:41:22 +00:00
for _, entry := range anyHandlers {
if entry.isInvalid() || entry.not(t) {
continue
2020-01-17 05:17:46 +00:00
}
entry.Call(v)
2020-01-17 05:17:46 +00:00
}
}
// WaitFor blocks until there's an event. It's advised to use ChanFor instead,
// as WaitFor may skip some events if it's not ran fast enough after the event
// arrived.
func (h *Handler) WaitFor(ctx context.Context, fn func(interface{}) bool) interface{} {
var result = make(chan interface{})
cancel := h.AddHandler(func(v interface{}) {
if fn(v) {
result <- v
}
})
defer cancel()
select {
case r := <-result:
return r
case <-ctx.Done():
return nil
}
}
// ChanFor returns a channel that would receive all incoming events that match
// the callback given. The cancel() function removes the handler and drops all
// hanging goroutines.
//
// This method is more intended to be used as a filter. For a persistent event
// channel, consider adding it directly as a handler with AddHandler.
func (h *Handler) ChanFor(fn func(interface{}) bool) (out <-chan interface{}, cancel func()) {
result := make(chan interface{})
closer := make(chan struct{})
2020-02-05 04:30:17 +00:00
removeHandler := h.AddHandler(func(v interface{}) {
2020-02-05 04:30:17 +00:00
if fn(v) {
select {
case result <- v:
case <-closer:
}
2020-02-05 04:30:17 +00:00
}
})
// Only allow cancel to be called once.
var once sync.Once
cancel = func() {
once.Do(func() {
removeHandler()
close(closer)
})
}
out = result
2020-02-05 04:30:17 +00:00
return
2020-02-05 04:30:17 +00:00
}
// AddHandler adds the handler, returning a function that would remove this
// handler when called. A handler type is either a single-argument no-return
// function or a channel.
//
// # Function
//
// A handler can be a function with a single argument that is the expected event
// type. It must not have any returns or any other number of arguments.
//
// // An example of a valid function handler.
// h.AddHandler(func(*gateway.MessageCreateEvent) {})
//
// # Channel
//
// A handler can also be a channel. The underlying type that the channel wraps
// around will be the event type. As such, the type rules are the same as
// function handlers.
//
// Keep in mind that the user must NOT close the channel. In fact, the channel
// should not be closed at all. The caller function WILL PANIC if the channel is
// closed!
//
// When the rm callback that is returned is called, it will also guarantee that
// all blocking sends will be cancelled. This helps prevent dangling goroutines.
//
// // An example of a valid channel handler.
// ch := make(chan *gateway.MessageCreateEvent)
// h.AddHandler(ch)
2020-01-17 05:17:46 +00:00
func (h *Handler) AddHandler(handler interface{}) (rm func()) {
rm, err := h.addHandler(handler, false)
if err != nil {
panic(err)
}
return rm
}
// AddSyncHandler is a synchronous variant of AddHandler. Handlers added using
// this method will block the Call method, which is helpful if the user needs to
// rely on the order of events arriving. Handlers added using this method should
// not block for very long, as it may clog up other handlers.
func (h *Handler) AddSyncHandler(handler interface{}) (rm func()) {
rm, err := h.addHandler(handler, true)
2020-01-17 05:17:46 +00:00
if err != nil {
panic(err)
}
return rm
}
// AddHandlerCheck adds the handler, but safe-guards reflect panics with a
// recoverer, returning the error. Refer to AddHandler for more information.
2020-01-17 05:17:46 +00:00
func (h *Handler) AddHandlerCheck(handler interface{}) (rm func(), err error) {
// Reflect would actually panic if anything goes wrong, so this is just in
// case.
defer func() {
if rec := recover(); rec != nil {
if recErr, ok := rec.(error); ok {
err = recErr
} else {
err = fmt.Errorf("%v", rec)
}
}
}()
return h.addHandler(handler, false)
2020-01-17 05:17:46 +00:00
}
// AddSyncHandlerCheck is the safe-guarded version of AddSyncHandler. It is
// similar to AddHandlerCheck.
func (h *Handler) AddSyncHandlerCheck(handler interface{}) (rm func(), err error) {
// Reflect would actually panic if anything goes wrong, so this is just in
// case.
defer func() {
if rec := recover(); rec != nil {
if recErr, ok := rec.(error); ok {
err = recErr
} else {
err = fmt.Errorf("%v", rec)
}
}
}()
return h.addHandler(handler, true)
}
func (h *Handler) addHandler(fn interface{}, sync bool) (rm func(), err error) {
2020-01-17 05:17:46 +00:00
// Reflect the handler
r, err := newHandler(fn, sync)
2020-01-17 05:17:46 +00:00
if err != nil {
return nil, fmt.Errorf("handler reflect failed: %w", err)
2020-01-17 05:17:46 +00:00
}
var id int
var t reflect.Type
if !r.isIface {
t = r.event
}
h.mutex.Lock()
if h.events == nil {
h.events = make(map[reflect.Type]slab, 10)
}
slab := h.events[t]
id = slab.Put(r)
h.events[t] = slab
h.mutex.Unlock()
2020-01-25 05:24:33 +00:00
2020-01-17 05:17:46 +00:00
return func() {
h.mutex.Lock()
slab := h.events[t]
popped := slab.Pop(id)
h.mutex.Unlock()
popped.cleanup()
2020-01-17 05:17:46 +00:00
}, nil
}
type handler struct {
event reflect.Type // underlying type; arg0 or chan underlying type
callback reflect.Value
chanclose reflect.Value // IsValid() if chan
isIface bool
isSync bool
isOnce bool
2020-01-17 05:17:46 +00:00
}
// newHandler reflects either a channel or a function into a handler. A function
// must only have a single argument being the event and no return, and a channel
// must have the event type as the underlying type.
func newHandler(unknown interface{}, sync bool) (handler, error) {
fnV := reflect.ValueOf(unknown)
2020-01-17 05:17:46 +00:00
fnT := fnV.Type()
// underlying event type
handler := handler{
callback: fnV,
isSync: sync,
}
2020-01-17 05:17:46 +00:00
switch fnT.Kind() {
case reflect.Func:
if fnT.NumIn() != 1 {
return handler, errors.New("function can only accept 1 event as argument")
}
if fnT.NumOut() > 0 {
return handler, errors.New("function can't accept returns")
}
2020-01-17 05:17:46 +00:00
handler.event = fnT.In(0)
case reflect.Chan:
handler.event = fnT.Elem()
handler.chanclose = reflect.ValueOf(make(chan struct{}))
default:
return handler, errors.New("given interface is not a function or channel")
2020-02-05 04:30:17 +00:00
}
var kind = handler.event.Kind()
2020-01-17 05:17:46 +00:00
// Accept either pointer type or interface{} type
if kind != reflect.Ptr && kind != reflect.Interface {
return handler, errors.New("first argument is not pointer")
2020-01-17 05:17:46 +00:00
}
handler.isIface = kind == reflect.Interface
return handler, nil
2020-01-17 05:17:46 +00:00
}
func (h handler) not(event reflect.Type) bool {
if h.isIface {
return !event.Implements(h.event)
}
return h.event != event
}
func (h handler) Call(event reflect.Value) {
if h.isSync {
h.call(event)
} else {
go h.call(event)
}
}
func (h handler) call(event reflect.Value) {
if h.chanclose.IsValid() {
reflect.Select([]reflect.SelectCase{
{Dir: reflect.SelectSend, Chan: h.callback, Send: event},
{Dir: reflect.SelectRecv, Chan: h.chanclose},
})
} else {
h.callback.Call([]reflect.Value{event})
}
2020-01-17 05:17:46 +00:00
}
func (h handler) cleanup() {
if h.chanclose.IsValid() {
// Closing this channel will force all ongoing selects to return
// immediately.
h.chanclose.Close()
}
}