Documentation ¶
Overview ¶
Package 发布订阅器对象
Package 发布订阅器对象 ¶
Package pubsub 发布订阅器对象 非常适合作为简单的广播模式的中间件
pubsubhelper 满足pchelper规定的生产者和消费者接口
Index ¶
- Variables
- func SerializeWithJSON() optparams.Option[Options]
- func SerializeWithMsgpack() optparams.Option[Options]
- func WithClientID(clientID string) optparams.Option[Options]
- func WithUUIDSnowflake() optparams.Option[Options]
- func WithUUIDSonyflake() optparams.Option[Options]
- func WithUUIDv4() optparams.Option[Options]
- type Consumer
- type Options
- type Producer
Constants ¶
This section is empty.
Variables ¶
var ErrNeedToPointOutTopics = errors.New("need to point out topics")
ErrNeedToPointOutTopics 需要指名发布订阅器
var ErrPubSubAlreadyListened = errors.New("pubsub already listened")
ErrPubSubAlreadyListened 发布订阅器已经被监听了
var ErrPubSubNotListeningYet = errors.New("pubsub not listening yet")
ErrPubSubNotListeningYet 发布订阅器未被监听
Functions ¶
func SerializeWithJSON ¶
SerializeWithJSON 使用JSON作为序列化反序列化的协议
func SerializeWithMsgpack ¶
SerializeWithMsgpack 使用JSON作为序列化反序列化的协议
func WithClientID ¶
WithClientID 中间件通用设置,设置客户端id
func WithUUIDSnowflake ¶
WithUUIDSnowflake 使用snowflake作为uuid的生成器
func WithUUIDSonyflake ¶
WithUUIDSonyflake 使用sonyflake作为uuid的生成器
Types ¶
type Consumer ¶
type Consumer struct { *clientIdhelper.ClientIDAbc *pchelper.ConsumerABC // contains filtered or unexported fields }
Consumer 发布订阅器消费者对象
func NewConsumer ¶
NewConsumer 创建一个新的发布订阅器消费者对象 @params cli redis.UniversalClient redis客户端对象 @params opts ...optparams.Option[Options] 消费者的配置
type Producer ¶
type Producer struct { *pchelper.ProducerConsumerABC *clientIdhelper.ClientIDAbc // contains filtered or unexported fields }
Producer 发布订阅器生产者对象
func NewProducer ¶
NewProducer 创建一个新的发布订阅器的生产者 @params cli redis.UniversalClient redis客户端对象 @params opts ...optparams.Option[Options] 生产者的配置
func (*Producer) PubEvent ¶
func (p *Producer) PubEvent(ctx context.Context, topic string, payload interface{}, opts ...optparams.Option[pchelper.PublishOptions]) (*pchelper.Event, error)
PubEvent 向发布订阅器中放入事件数据 @params ctx context.Context 请求的上下文 @params topic string 发送去的指定频道 @params payload []byte 发送的消息负载 @params opts ...optparams.Option[pchelper.PublishOptions] 无效 @returns *pchelper.Event 发送出去的消息对象
func (*Producer) Publish ¶
func (p *Producer) Publish(ctx context.Context, topic string, payload interface{}, opts ...optparams.Option[pchelper.PublishOptions]) error
Publish 向队列中放入数据 @params ctx context.Context 请求的上下文 @params topic string 发送去的指定频道 @params payload interface{} 发送的消息负载,负载支持string,bytes,bool,number,以及可以被json或者msgpack序列化的对象 @params opts ...optparams.Option[pchelper.PublishOptions] 无效