Versions in this module Expand all Collapse all v1 v1.0.0 Apr 9, 2020 Changes in this version + const AdjustCconsumerThreadPoolPOOL + const Async + const BenchmarkTopic + const BrokerSuspendMaxTimeMillis + const CconsumerSendMsgBack + const CharacterMaxLength + const CheckTransactionState + const CidOnsapiOwnerGroup + const CidOnsapiPermissionGroup + const CidOnsapiPullGroup + const CidRmqSysPerfix + const CleanExpiredConsumequeue + const ClientInnerProducerGroup + const CloneGroupOffset + const CompressedFlag + const ConsumeMsgDirectly + const ConsumeMsgTimeout + const ConsumerNotOnline + const CreateJust + const DefaultCharset + const DefaultConsumerGroup + const DefaultProducerGroup + const DefaultTopic + const DelayMsg + const DeleteKVConfig + const DeleteKvConfigByValue + const DeleteSubscriptionGroup + const DeleteTopicInBroker + const DeleteTopicInNamesrv + const DlqGroupTopicPerfix + const EndTransaction + const FiltersrvConsumerGroup + const FlagClassFilter + const FlagCommitOffset + const FlagSubscription + const FlagSuspend + const FlushDiskTimeout + const FlushSlaveTimeout + const GetAllCconsumerOffset + const GetAllDelayOffset + const GetAllSubscriptionGroupConfig + const GetAllTopicConfig + const GetAllTopicListFromNamesrv + const GetBrokerClusterInfo + const GetBrokerConfig + const GetBrokerRuntimeInfo + const GetCconsumerRunningInfo + const GetCconsumerStatusFromClient + const GetConsumeStats + const GetConsumerConnList + const GetConsumerListByGroup + const GetEarliestMsgStoreTime + const GetHasUnitSubTopicList + const GetHasUnitSubUnunitTopicList + const GetKVConfig + const GetKvConfigByValue + const GetKvlistByNamespace + const GetMaxOffset + const GetMinOffset + const GetProducerConnList + const GetRouteinfoByTopic + const GetSysTopicListFromBroker + const GetSysTopicListFromNS + const GetTopicConfigList + const GetTopicNameList + const GetTopicStatsInfo + const GetTopicsByCluster + const GetUnitTopicList + const HeartBeat + const InvokeBrokerToGetCconsumerSTATUS + const InvokeBrokerToResetOffset + const Localhost + const LockBatchMq + const MasterId + const MemoryFirstThenStore + const MessageCompressLevel + const MonitrorConsumerGroup + const MsgIllegal + const MultiTagsFlag + const NameValueSeparator + const NamesrvAddrEnv + const NamesrvAddrProperty + const NoBuyerId + const NoPermission + const NormalMsg + const NotInCurrentUint + const NotifyConsumerIdsChanged + const OffsetMovedEvent + const Oneway + const OnsHttpProxyGroup + const PropertySeparator + const PullMsg + const PullNotFound + const PullOffsetMoved + const PullRetryImmediately + const PutKVConfig + const QueryBrokerOffset + const QueryConsumeTimeSpan + const QueryConsumerOffset + const QueryCorrectionOffset + const QueryMESSAGE + const QueryNotFound + const QueryTopicConsumeByWho + const ReadFromMemory + const ReadFromStore + const RegisterBroker + const RegisterFilterServer + const RegisterMsgFilterClass + const RequestCodeNotSupported + const ResetCconsumerClientOffset + const ResetCconsumerOffsetInBroker + const ResetCconsumerOffsetInConsumer + const ResumeConsumer + const RetryGroupTopicPrefix + const RocketmqHomeEnv + const RocketmqHomeProperty + const RpcOneway + const RpcType + const Running + const SearchOffsetByTimeStamp + const SelfTestConsumerGroup + const SelfTestProducerGroup + const SelfTestTopic + const SendMsg + const SendMsgV2 + const SendStatusFlushDiskTimeout + const SendStatusFlushSlaveTimeout + const SendStatusOK + const SendStatusSlaveNotAvailable + const ServiceNotAvailable + const ShutdownAlready + const SlaveNotAvailable + const StartFailed + const SubscriptionGroupNotExist + const SubscriptionNotExist + const SubscriptionNotLatest + const SubscriptionParseFailed + const Success + const SuspendConsumer + const Sync + const SysBusy + const SysError + const SysTopicPerfix + const ToolsConsumerGroup + const TopicExistAlready + const TopicNotExist + const TransMsgCommit + const TransMsgHalf + const TransactionCommitType + const TransactionFailed + const TransactionNotType + const TransactionPreparedType + const TransactionRollbackType + const TransactionShouldCommit + const TransactionShouldRollback + const TransactionStateGroupWrong + const TransactionStateUnknow + const TriggerDeleteFILES + const UNLockBatchMq + const UniqMsgQueryFlag + const UnregisterBroker + const UnregisterClient + const UpdateAndCreateSubscriptionGroup + const UpdateAndCreateTopic + const UpdateBrokerConfig + const UpdateCconsumerOffset + const VersionNotSupported + const ViewBrokerStatsData + const ViewMsgById + const WhoConsumeTHE_MESSAGE + const WipeWritePermOfBroker + const WsAddr + const WsDomainName + const WsDomainSubgroup + var ConfigVersion int = -1 + var DefaultIp = GetLocalIp4() + var MessageClientIDSetter = messageClientIDSetter + var MessageConst = &messageConst + var PermName = permName + func BrokerVIPChannel(isChange bool, brokerAddr string) (borkerAddrNew string) + func GetLocalIp4() (ip string) + type Admin interface + type AllocateMessageQueueAveragely struct + type AllocateMessageQueueStrategy interface + type BrokerData struct + BrokerAddrs map[string]string + BrokerAddrsLock sync.RWMutex + BrokerName string + type Config struct + ClientIp string + InstanceName string + Namesrv string + type Consumer interface + RegisterMessageListener func(listener MessageListener) + SendMessageBack func(msg MessageExt, delayLevel int) error + SendMessageBack1 func(msg MessageExt, delayLevel int, brokerName string) error + Shutdown func() + Start func() error + Subscribe func(topic string, subExpression string) + UnSubscribe func(topic string) + func NewDefaultConsumer(consumerGroup string, conf *Config) (Consumer, error) + type ConsumerData struct + ConsumeFromWhere string + ConsumerType string + GroupName string + MessageModel string + SubscriptionDataSet []*SubscriptionData + UnitMode bool + type ConsumerIdSorter []string + func (r ConsumerIdSorter) Len() int + func (r ConsumerIdSorter) Less(i, j int) bool + func (r ConsumerIdSorter) Swap(i, j int) + type DefaultConsumer struct + func (c *DefaultConsumer) RegisterMessageListener(messageListener MessageListener) + func (c *DefaultConsumer) SendMessageBack(msg MessageExt, delayLevel int) error + func (c *DefaultConsumer) SendMessageBack1(msg MessageExt, delayLevel int, brokerName string) error + func (c *DefaultConsumer) Shutdown() + func (c *DefaultConsumer) Start() error + func (c *DefaultConsumer) Subscribe(topic string, subExpression string) + func (c *DefaultConsumer) UnSubscribe(topic string) + type DefaultProducer struct + func (d *DefaultProducer) Send(msg *Message) (*SendResult, error) + func (d *DefaultProducer) SendAsync(msg *Message, sendCallback SendCallback) (err error) + func (d *DefaultProducer) SendOneway(msg *Message) error + func (d *DefaultProducer) Shutdown() + func (d *DefaultProducer) Start() error + type DefaultRemotingClient struct + func (d *DefaultRemotingClient) ScanResponseTable() + type GetConsumerListByGroupRequestHeader struct + ConsumerGroup string + type GetConsumerListByGroupResponseBody struct + ConsumerIdList []string + type GetRouteInfoRequestHeader struct + func (g *GetRouteInfoRequestHeader) MarshalJSON() ([]byte, error) + type HeartbeatData struct + ClientId string + ConsumerDataSet []*ConsumerData + type InvokeCallback func(responseFuture *ResponseFuture) + type Message struct + Body []byte + Flag int32 + Properties map[string]string + Topic string + func NewMessage(topic string, body []byte) *Message + type MessageExt struct + BodyCRC int32 + BornTimestamp int64 + CommitLogOffset int64 + MsgId string + PreparedTransactionOffset int64 + QueueId int32 + QueueOffset int64 + ReconsumeTimes int32 + StoreSize int32 + StoreTimestamp int64 + SysFlag int32 + type MessageListener func(msgs []*MessageExt) error + type MessageQueue struct + func NewMessageQueue(topic string, brokerName string, queueId int32) *MessageQueue + type MessageQueues []*MessageQueue + func (m MessageQueues) Len() int + func (m MessageQueues) Less(i, j int) bool + func (m MessageQueues) Swap(i, j int) + type MixAll struct + type MqClient struct + func NewMqClient() *MqClient + type OffsetStore interface + type Producer interface + Send func(msg *Message) (*SendResult, error) + SendAsync func(msg *Message, sendCallback SendCallback) error + SendOneway func(msg *Message) error + Shutdown func() + Start func() error + func NewDefaultProducer(producerGroup string, conf *Config) (Producer, error) + type PullMessageRequestHeader struct + CommitOffset int64 + ConsumerGroup string + MaxMsgNums int32 + QueueId int32 + QueueOffset int64 + SubVersion int64 + Subscription string + SuspendTimeoutMillis int64 + SysFlag int32 + Topic string + type PullMessageService struct + func NewPullMessageService() *PullMessageService + type PullRequest struct + type QueryConsumerOffsetRequestHeader struct + ConsumerGroup string + QueueId int32 + Topic string + type QueueData struct + BrokerName string + Perm int + ReadQueueNums int32 + TopicSynFlag int32 + WriteQueueNums int32 + type Rebalance struct + func NewRebalance() *Rebalance + type RemoteOffsetStore struct + type RemotingClient interface + ScanResponseTable func() + func NewDefaultRemotingClient() RemotingClient + type RemotingCommand struct + Body []byte + Code int + ExtFields interface{} + Flag int + Language string + Opaque int32 + Version int + type ResponseFuture struct + type SendCallback func() error + type SendMessageContext struct + Message Message + type SendMessageRequestHeader struct + BornTimestamp int64 + DefaultTopic string + DefaultTopicQueueNums int + Flag int32 + MaxReconsumeTimes int + ProducerGroup string + Properties string + QueueId int32 + ReconsumeTimes int + SysFlag int + Topic string + UnitMode bool + type SendMessageResponseHeader struct + type SendMessageService struct + func NewSendMessageService() *SendMessageService + type SendRequest struct + type SendResult struct + func NewSendResult(sendStatus int, msgId string, offsetMsgId string, messageQueue *MessageQueue, ...) *SendResult + func (s *SendResult) SendResult(SendStatus int, msgId string, messageQueue MessageQueue, queueOffset uint64, ...) (ok bool) + type Service interface + type SubscriptionData struct + ClassFilterMode bool + CodeSet []string + SubString string + SubVersion int64 + TagsSet []string + Topic string + type TopicPublishInfo struct + func NewTopicPublishInfo() *TopicPublishInfo + type TopicRouteData struct + BrokerDatas []*BrokerData + OrderTopicConf string + QueueDatas []*QueueData + type UpdateConsumerOffsetRequestHeader struct