You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@inlong.apache.org by GitBox <gi...@apache.org> on 2022/08/15 11:22:52 UTC

[GitHub] [inlong] gosonzhang opened a new pull request, #5552: [INLONG-5551][DataProxy] Add metric log output information in TubeSink

gosonzhang opened a new pull request, #5552:
URL: https://github.com/apache/inlong/pull/5552

   - Fixes #5551
   
   


-- 
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: commits-unsubscribe@inlong.apache.org

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


[GitHub] [inlong] gosonzhang commented on a diff in pull request #5552: [INLONG-5551][DataProxy] Add metric log output information in TubeSink

Posted by GitBox <gi...@apache.org>.
gosonzhang commented on code in PR #5552:
URL: https://github.com/apache/inlong/pull/5552#discussion_r946288809


##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -338,8 +385,9 @@ public void run() {
                         }
                     }
                     if (LOG_SINK_TASK_PRINTER.shouldPrint()) {
-                        logger.error("Sink task fail to send the message, finished =" + sendFinished
-                                + ",sink.name=" + Thread.currentThread().getName()
+                        logger.error("Sink task fail to send the message, finished ="
+                                + bChangedInflightValue + ",sink.name="
+                                + Thread.currentThread().getName()

Review Comment:
   done



-- 
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: commits-unsubscribe@inlong.apache.org

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


[GitHub] [inlong] gosonzhang merged pull request #5552: [INLONG-5551][DataProxy] Add metric log output information in TubeSink

Posted by GitBox <gi...@apache.org>.
gosonzhang merged PR #5552:
URL: https://github.com/apache/inlong/pull/5552


-- 
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: commits-unsubscribe@inlong.apache.org

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


[GitHub] [inlong] baomingyu commented on a diff in pull request #5552: [INLONG-5551][DataProxy] Add metric log output information in TubeSink

Posted by GitBox <gi...@apache.org>.
baomingyu commented on code in PR #5552:
URL: https://github.com/apache/inlong/pull/5552#discussion_r945653037


##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -121,6 +133,10 @@ public void configure(Context context) {
         // create producer holder
         producerHolder = new TubeProducerHolder(getName(),
                 usedMasterAddr, configManager.getMqClusterConfig());
+        // get statistic configure items
+        maxMonitorCnt = context.getInteger("max-monitor-cnt", 300000);

Review Comment:
   move  "max-monitor-cnt" to  ConfigConstants class



##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -338,8 +385,9 @@ public void run() {
                         }
                     }
                     if (LOG_SINK_TASK_PRINTER.shouldPrint()) {
-                        logger.error("Sink task fail to send the message, finished =" + sendFinished
-                                + ",sink.name=" + Thread.currentThread().getName()
+                        logger.error("Sink task fail to send the message, finished ="
+                                + bChangedInflightValue + ",sink.name="
+                                + Thread.currentThread().getName()

Review Comment:
   suggest use {} as a placeholder



##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -317,19 +363,20 @@ public void run() {
                     if (StringUtils.isBlank(topic)) {
                         blankTopicDiscardMsgCnt.incrementAndGet();
                         takenMsgCnt.decrementAndGet();
+                        monitorIndexExt.incrementAndGet("TUBE_SINK_DROPPED");

Review Comment:
   "TUBE_SINK_DROPPED"  as a static field



-- 
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: commits-unsubscribe@inlong.apache.org

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


[GitHub] [inlong] gosonzhang commented on a diff in pull request #5552: [INLONG-5551][DataProxy] Add metric log output information in TubeSink

Posted by GitBox <gi...@apache.org>.
gosonzhang commented on code in PR #5552:
URL: https://github.com/apache/inlong/pull/5552#discussion_r946303925


##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -121,6 +137,10 @@ public void configure(Context context) {
         // create producer holder
         producerHolder = new TubeProducerHolder(getName(),
                 usedMasterAddr, configManager.getMqClusterConfig());
+        // get statistic configure items
+        maxMonitorCnt = context.getInteger(MAX_MONITOR_CNT, 300000);
+        statIntervalSec = context.getInteger(STAT_INTERVAL_SEC, 60);

Review Comment:
   done



-- 
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: commits-unsubscribe@inlong.apache.org

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


[GitHub] [inlong] gosonzhang commented on a diff in pull request #5552: [INLONG-5551][DataProxy] Add metric log output information in TubeSink

Posted by GitBox <gi...@apache.org>.
gosonzhang commented on code in PR #5552:
URL: https://github.com/apache/inlong/pull/5552#discussion_r946288733


##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -121,6 +133,10 @@ public void configure(Context context) {
         // create producer holder
         producerHolder = new TubeProducerHolder(getName(),
                 usedMasterAddr, configManager.getMqClusterConfig());
+        // get statistic configure items
+        maxMonitorCnt = context.getInteger("max-monitor-cnt", 300000);

Review Comment:
   done



##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -317,19 +363,20 @@ public void run() {
                     if (StringUtils.isBlank(topic)) {
                         blankTopicDiscardMsgCnt.incrementAndGet();
                         takenMsgCnt.decrementAndGet();
+                        monitorIndexExt.incrementAndGet("TUBE_SINK_DROPPED");

Review Comment:
   done



-- 
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: commits-unsubscribe@inlong.apache.org

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


[GitHub] [inlong] dockerzhang commented on a diff in pull request #5552: [INLONG-5551][DataProxy] Add metric log output information in TubeSink

Posted by GitBox <gi...@apache.org>.
dockerzhang commented on code in PR #5552:
URL: https://github.com/apache/inlong/pull/5552#discussion_r946302222


##########
inlong-dataproxy/dataproxy-source/src/main/java/org/apache/inlong/dataproxy/sink/TubeSink.java:
##########
@@ -121,6 +137,10 @@ public void configure(Context context) {
         // create producer holder
         producerHolder = new TubeProducerHolder(getName(),
                 usedMasterAddr, configManager.getMqClusterConfig());
+        // get statistic configure items
+        maxMonitorCnt = context.getInteger(MAX_MONITOR_CNT, 300000);
+        statIntervalSec = context.getInteger(STAT_INTERVAL_SEC, 60);

Review Comment:
   make the configurations shown in config files.



-- 
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: commits-unsubscribe@inlong.apache.org

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