You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@rocketmq.apache.org by GitBox <gi...@apache.org> on 2021/05/22 03:52:58 UTC

[GitHub] [rocketmq-client-go] fumenglin opened a new issue #666: tackType = UNKNOWN ;result=com.alibaba.fastjson.JSONException: No enum constant org.apache.rocketmq.remoting.protocol.LanguageCode.GO, com.alibaba.fastjson.parser.DefaultJSONParser.parseObject(DefaultJSONParser.java:614)

fumenglin opened a new issue #666:
URL: https://github.com/apache/rocketmq-client-go/issues/666


   核心代码如下:
   traceCfg := &primitive.TraceConfig{
   		Access:   primitive.Local,
   		Resolver: primitive.NewPassthroughResolver(addrs),
   	}
   	TopicConsumer := "topic"
   	ConsumerGroupName := "consumer"
   	c, _ := rocketmq.NewPushConsumer(
   		consumer.WithGroupName(ConsumerGroupName),
   		consumer.WithNsResovler(primitive.NewPassthroughResolver(addrs)),
   		consumer.WithTrace(traceCfg),
   	)
   	err := c.Subscribe(TopicConsumer, consumer.MessageSelector{}, func(ctx context.Context,
   		msgs ...*primitive.MessageExt) (consumer.ConsumeResult, error) {
   		for i := range msgs {
   					waybillMsg := msgs[i]
   					t.Log(waybillMsg.OffsetMsgId)
   					t.Log(string(waybillMsg.Body))
   				}
   		return consumer.ConsumeSuccess, nil
   	})
   	if err != nil {
   		fmt.Println(err.Error())
   	}
   	// Note: start after subscribe
   	err = c.Start()
   	if err != nil {
   		fmt.Println(err.Error())
   
   	}
   	time.Sleep(time.Hour)
   	err = c.Shutdown()
   	if err != nil {
   		fmt.Printf("shutdown Consumer error: %s", err.Error())
   	}
   
   但是在监控端;显示的:tackType = UNKNOWN ;result=com.alibaba.fastjson.JSONException: No enum constant org.apache.rocketmq.remoting.protocol.LanguageCode.GO, com.alibaba.fastjson.parser.DefaultJSONParser.parseObject(DefaultJSONParser.java:614)
   
   请问是trace用的不对么;


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq-client-go] bilinxing commented on issue #666: tackType = UNKNOWN ;result=com.alibaba.fastjson.JSONException: No enum constant org.apache.rocketmq.remoting.protocol.LanguageCode.GO, com.alibaba.fastjson.parser.DefaultJSONParser.parseObject(DefaultJSONParser.java:614)

Posted by GitBox <gi...@apache.org>.
bilinxing commented on issue #666:
URL: https://github.com/apache/rocketmq-client-go/issues/666#issuecomment-847858807


   Probably because you used an old version of the docker image of rocketmq-console, for example:https://hub.docker.com/r/styletang/rocketmq-console-ng. Just replace it with the new version: https://hub.docker.com/r /apacherocketmq/rocketmq-console


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq-client-go] bilinxing removed a comment on issue #666: tackType = UNKNOWN ;result=com.alibaba.fastjson.JSONException: No enum constant org.apache.rocketmq.remoting.protocol.LanguageCode.GO, com.alibaba.fastjson.parser.DefaultJSONParser.parseObject(DefaultJSONParser.java:614)

Posted by GitBox <gi...@apache.org>.
bilinxing removed a comment on issue #666:
URL: https://github.com/apache/rocketmq-client-go/issues/666#issuecomment-847858807


   Probably because you used an old version of the docker image of rocketmq-console, for example:https://hub.docker.com/r/styletang/rocketmq-console-ng. Just replace it with the new version: https://hub.docker.com/r /apacherocketmq/rocketmq-console


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq-client-go] wenfengwang commented on issue #666: tackType = UNKNOWN ;result=com.alibaba.fastjson.JSONException: No enum constant org.apache.rocketmq.remoting.protocol.LanguageCode.GO, com.alibaba.fastjson.parser.DefaultJSONParser.parseObject(DefaultJSONParser.java:614)

Posted by GitBox <gi...@apache.org>.
wenfengwang commented on issue #666:
URL: https://github.com/apache/rocketmq-client-go/issues/666#issuecomment-872217886


   > Probably because you used an old version of the docker image of rocketmq-console, for example:https://hub.docker.com/r/styletang/rocketmq-console-ng. Just replace it with the new version: https://hub.docker.com/r/apacherocketmq/rocketmq-console
   
   thanks @bilinxing ,  does the solution working? @fumenglin 


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: dev-unsubscribe@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq-client-go] vongosling closed issue #666: tackType = UNKNOWN ;result=com.alibaba.fastjson.JSONException: No enum constant org.apache.rocketmq.remoting.protocol.LanguageCode.GO, com.alibaba.fastjson.parser.DefaultJSONParser.parseObject(DefaultJSONParser.java:614)

Posted by GitBox <gi...@apache.org>.
vongosling closed issue #666:
URL: https://github.com/apache/rocketmq-client-go/issues/666


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: dev-unsubscribe@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq-client-go] bilinxing commented on issue #666: tackType = UNKNOWN ;result=com.alibaba.fastjson.JSONException: No enum constant org.apache.rocketmq.remoting.protocol.LanguageCode.GO, com.alibaba.fastjson.parser.DefaultJSONParser.parseObject(DefaultJSONParser.java:614)

Posted by GitBox <gi...@apache.org>.
bilinxing commented on issue #666:
URL: https://github.com/apache/rocketmq-client-go/issues/666#issuecomment-847858933


   Probably because you used an old version of the docker image of rocketmq-console, for example:https://hub.docker.com/r/styletang/rocketmq-console-ng. Just replace it with the new version: https://hub.docker.com/r/apacherocketmq/rocketmq-console


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org