mirror of
https://github.com/EchoVault/SugarDB.git
synced 2025-10-05 16:06:57 +08:00
254 lines
7.6 KiB
Go
254 lines
7.6 KiB
Go
// Copyright 2024 Kelvin Clement Mwinuka
|
|
//
|
|
// Licensed under the Apache License, Version 2.0 (the "License");
|
|
// you may not use this file except in compliance with the License.
|
|
// You may obtain a copy of the License at
|
|
//
|
|
// http://www.apache.org/licenses/LICENSE-2.0
|
|
//
|
|
// Unless required by applicable law or agreed to in writing, software
|
|
// distributed under the License is distributed on an "AS IS" BASIS,
|
|
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
|
// See the License for the specific language governing permissions and
|
|
// limitations under the License.
|
|
|
|
package echovault
|
|
|
|
import (
|
|
"bytes"
|
|
"errors"
|
|
"github.com/echovault/echovault/internal"
|
|
"github.com/tidwall/resp"
|
|
"net"
|
|
"strings"
|
|
"sync"
|
|
)
|
|
|
|
type conn struct {
|
|
readConn *net.Conn
|
|
writeConn *net.Conn
|
|
}
|
|
|
|
var connections sync.Map
|
|
|
|
// ReadPubSubMessage is returned by the Subscribe and PSubscribe functions.
|
|
//
|
|
// This function is lazy, therefore it needs to be invoked in order to read the next message.
|
|
// When the message is read, the function returns a string slice with 3 elements.
|
|
// Index 0 holds the event type which in this case will be "message". Index 1 holds the channel name.
|
|
// Index 2 holds the actual message.
|
|
type ReadPubSubMessage func() []string
|
|
|
|
func establishConnections(tag string) (*net.Conn, *net.Conn, error) {
|
|
var readConn *net.Conn
|
|
var writeConn *net.Conn
|
|
|
|
if _, ok := connections.Load(tag); !ok {
|
|
// If connection with this name does not exist, create new connection.
|
|
rc, wc := net.Pipe()
|
|
readConn = &rc
|
|
writeConn = &wc
|
|
connections.Store(tag, conn{
|
|
readConn: &rc,
|
|
writeConn: &wc,
|
|
})
|
|
} else {
|
|
// Reuse existing connection.
|
|
c, ok := connections.Load(tag)
|
|
if !ok {
|
|
return nil, nil, errors.New("could not establish connection")
|
|
}
|
|
readConn = c.(conn).readConn
|
|
writeConn = c.(conn).writeConn
|
|
}
|
|
|
|
return readConn, writeConn, nil
|
|
}
|
|
|
|
// Subscribe subscribes the caller to the list of provided channels.
|
|
//
|
|
// Parameters:
|
|
//
|
|
// `tag` - string - The tag used to identify this subscription instance.
|
|
//
|
|
// `channels` - ...string - The list of channels to subscribe to.
|
|
//
|
|
// Returns: ReadPubSubMessage function which reads the next message sent to the subscription instance.
|
|
// This function is blocking.
|
|
func (server *EchoVault) Subscribe(tag string, channels ...string) (ReadPubSubMessage, error) {
|
|
readConn, writeConn, err := establishConnections(tag)
|
|
if err != nil {
|
|
return func() []string {
|
|
return []string{}
|
|
}, err
|
|
}
|
|
|
|
// Subscribe connection to the provided channels.
|
|
cmd := append([]string{"SUBSCRIBE"}, channels...)
|
|
go func() {
|
|
_, _ = server.handleCommand(server.context, internal.EncodeCommand(cmd), writeConn, false, true)
|
|
}()
|
|
|
|
return func() []string {
|
|
r := resp.NewConn(*readConn)
|
|
v, _, _ := r.ReadValue()
|
|
|
|
res := make([]string, len(v.Array()))
|
|
for i := 0; i < len(res); i++ {
|
|
res[i] = v.Array()[i].String()
|
|
}
|
|
|
|
return res
|
|
}, nil
|
|
}
|
|
|
|
// Unsubscribe unsubscribes the caller from the given channels.
|
|
//
|
|
// Parameters:
|
|
//
|
|
// `tag` - string - The tag used to identify this subscription instance.
|
|
//
|
|
// `channels` - ...string - The list of channels to unsubscribe from.
|
|
func (server *EchoVault) Unsubscribe(tag string, channels ...string) {
|
|
c, ok := connections.Load(tag)
|
|
if !ok {
|
|
return
|
|
}
|
|
cmd := append([]string{"UNSUBSCRIBE"}, channels...)
|
|
_, _ = server.handleCommand(server.context, internal.EncodeCommand(cmd), c.(conn).writeConn, false, true)
|
|
}
|
|
|
|
// PSubscribe subscribes the caller to the list of provided glob patterns.
|
|
//
|
|
// Parameters:
|
|
//
|
|
// `tag` - string - The tag used to identify this subscription instance.
|
|
//
|
|
// `patterns` - ...string - The list of glob patterns to subscribe to.
|
|
//
|
|
// Returns: ReadPubSubMessage function which reads the next message sent to the subscription instance.
|
|
// This function is blocking.
|
|
func (server *EchoVault) PSubscribe(tag string, patterns ...string) (ReadPubSubMessage, error) {
|
|
readConn, writeConn, err := establishConnections(tag)
|
|
if err != nil {
|
|
return func() []string {
|
|
return []string{}
|
|
}, err
|
|
}
|
|
|
|
// Subscribe connection to the provided channels
|
|
cmd := append([]string{"PSUBSCRIBE"}, patterns...)
|
|
go func() {
|
|
_, _ = server.handleCommand(server.context, internal.EncodeCommand(cmd), writeConn, false, true)
|
|
}()
|
|
|
|
return func() []string {
|
|
r := resp.NewConn(*readConn)
|
|
v, _, _ := r.ReadValue()
|
|
|
|
res := make([]string, len(v.Array()))
|
|
for i := 0; i < len(res); i++ {
|
|
res[i] = v.Array()[i].String()
|
|
}
|
|
|
|
return res
|
|
}, nil
|
|
}
|
|
|
|
// PUnsubscribe unsubscribes the caller from the given glob patterns.
|
|
//
|
|
// Parameters:
|
|
//
|
|
// `tag` - string - The tag used to identify this subscription instance.
|
|
//
|
|
// `patterns` - ...string - The list of glob patterns to unsubscribe from.
|
|
func (server *EchoVault) PUnsubscribe(tag string, patterns ...string) {
|
|
c, ok := connections.Load(tag)
|
|
if !ok {
|
|
return
|
|
}
|
|
cmd := append([]string{"PUNSUBSCRIBE"}, patterns...)
|
|
_, _ = server.handleCommand(server.context, internal.EncodeCommand(cmd), c.(conn).writeConn, false, true)
|
|
}
|
|
|
|
// Publish publishes a message to the given channel.
|
|
//
|
|
// Parameters:
|
|
//
|
|
// `channel` - string - The channel to publish the message to.
|
|
//
|
|
// `message` - string - The message to publish to the specified channel.
|
|
//
|
|
// Returns: true when the publish is successful. This does not indicate whether each subscriber has received the message,
|
|
// only that the message has been published.
|
|
func (server *EchoVault) Publish(channel, message string) (bool, error) {
|
|
b, err := server.handleCommand(server.context, internal.EncodeCommand([]string{"PUBLISH", channel, message}), nil, false, true)
|
|
if err != nil {
|
|
return false, err
|
|
}
|
|
s, err := internal.ParseStringResponse(b)
|
|
return strings.EqualFold(s, "ok"), err
|
|
}
|
|
|
|
// PubSubChannels returns the list of channels & patterns that match the glob pattern provided.
|
|
//
|
|
// Parameters:
|
|
//
|
|
// `pattern` - string - The glob pattern used to match the channel names.
|
|
//
|
|
// Returns: A string slice of all the active channels and patterns (i.e. channels and patterns that have 1 or more subscribers).
|
|
func (server *EchoVault) PubSubChannels(pattern string) ([]string, error) {
|
|
cmd := []string{"PUBSUB", "CHANNELS"}
|
|
if pattern != "" {
|
|
cmd = append(cmd, pattern)
|
|
}
|
|
b, err := server.handleCommand(server.context, internal.EncodeCommand(cmd), nil, false, true)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
return internal.ParseStringArrayResponse(b)
|
|
}
|
|
|
|
// PubSubNumPat returns the list of active patterns.
|
|
//
|
|
// Returns: An integer representing the number of all the active patterns (i.e. patterns that have 1 or more subscribers).
|
|
func (server *EchoVault) PubSubNumPat() (int, error) {
|
|
b, err := server.handleCommand(server.context, internal.EncodeCommand([]string{"PUBSUB", "NUMPAT"}), nil, false, true)
|
|
if err != nil {
|
|
return 0, err
|
|
}
|
|
return internal.ParseIntegerResponse(b)
|
|
}
|
|
|
|
// PubSubNumSub returns the number of subscribers for each of the specified channels.
|
|
//
|
|
// Parameters:
|
|
//
|
|
// `channels` - ...string - The list of channels whose number of subscribers is to be checked.
|
|
//
|
|
// Returns: A map of map[string]int where the key is the channel name and the value is the number of subscribers.
|
|
func (server *EchoVault) PubSubNumSub(channels ...string) (map[string]int, error) {
|
|
cmd := append([]string{"PUBSUB", "NUMSUB"}, channels...)
|
|
|
|
b, err := server.handleCommand(server.context, internal.EncodeCommand(cmd), nil, false, true)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
r := resp.NewReader(bytes.NewReader(b))
|
|
v, _, err := r.ReadValue()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
arr := v.Array()
|
|
|
|
result := make(map[string]int, len(arr))
|
|
for _, entry := range arr {
|
|
e := entry.Array()
|
|
result[e[0].String()] = e[1].Integer()
|
|
}
|
|
|
|
return result, nil
|
|
}
|