You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "ASF GitHub Bot (JIRA)" <ji...@apache.org> on 2016/05/05 17:10:13 UTC

[jira] [Commented] (FLINK-1502) Expose metrics to graphite, ganglia and JMX.

    [ https://issues.apache.org/jira/browse/FLINK-1502?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=15272654#comment-15272654 ] 

ASF GitHub Bot commented on FLINK-1502:
---------------------------------------

Github user rmetzger commented on the pull request:

    https://github.com/apache/flink/pull/1947#issuecomment-217213101
  
    Is it possible that submitting the same job two times doesn't work?
    
    ```
    ./bin/flink run ./examples/streaming/SocketWindowWordCount.jar --port 54323
    
    05/05/2016 19:09:08	Job execution switched to status RUNNING.
    05/05/2016 19:09:08	Source: Socket Stream -> Flat Map(1/1) switched to SCHEDULED 
    05/05/2016 19:09:08	Source: Socket Stream -> Flat Map(1/1) switched to DEPLOYING 
    05/05/2016 19:09:08	Fast SlidingProcessingTimeWindows(5000, 1000) of WindowedStream.main(SocketWindowWordCount.java:79) -> Sink: Unnamed(1/1) switched to SCHEDULED 
    05/05/2016 19:09:08	Fast SlidingProcessingTimeWindows(5000, 1000) of WindowedStream.main(SocketWindowWordCount.java:79) -> Sink: Unnamed(1/1) switched to DEPLOYING 
    05/05/2016 19:09:08	Source: Socket Stream -> Flat Map(1/1) switched to RUNNING 
    05/05/2016 19:09:08	Source: Socket Stream -> Flat Map(1/1) switched to FAILED 
    java.lang.IllegalArgumentException: This group ([key0, localhost, Actor, TaskManager, TaskManager, 964566cfcf032710aff86614010fce21, Category, Tasks, Job, "Socket Window WordCount", Operator, Flat Map, SubTask, 0, ChannelType, OutputChannel, Index, 0]) already contains a metric named numBytesOut
    	at org.apache.flink.metrics.MetricGroup.addMetric(MetricGroup.java:246)
    	at org.apache.flink.metrics.MetricGroup.counter(MetricGroup.java:123)
    	at org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer.setMetrics(SpanningRecordSerializer.java:206)
    	at org.apache.flink.runtime.io.network.api.writer.RecordWriter.setMetrics(RecordWriter.java:216)
    	at org.apache.flink.streaming.runtime.tasks.OperatorChain.createStreamOutput(OperatorChain.java:294)
    	at org.apache.flink.streaming.runtime.tasks.OperatorChain.<init>(OperatorChain.java:94)
    	at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:188)
    	at org.apache.flink.runtime.taskmanager.Task.run(Task.java:584)
    	at java.lang.Thread.run(Thread.java:745)
    
    05/05/2016 19:09:08	Fast SlidingProcessingTimeWindows(5000, 1000) of WindowedStream.main(SocketWindowWordCount.java:79) -> Sink: Unnamed(1/1) switched to RUNNING 
    05/05/2016 19:09:08	Job execution switched to status FAILING.
    
    ```


> Expose metrics to graphite, ganglia and JMX.
> --------------------------------------------
>
>                 Key: FLINK-1502
>                 URL: https://issues.apache.org/jira/browse/FLINK-1502
>             Project: Flink
>          Issue Type: Sub-task
>          Components: JobManager, TaskManager
>    Affects Versions: 0.9
>            Reporter: Robert Metzger
>            Assignee: Chesnay Schepler
>            Priority: Minor
>             Fix For: pre-apache
>
>
> The metrics library allows to expose collected metrics easily to other systems such as graphite, ganglia or Java's JVM (VisualVM).



--
This message was sent by Atlassian JIRA
(v6.3.4#6332)