You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@storm.apache.org by Hugo Louro <hl...@hortonworks.com> on 2015/07/10 04:59:46 UTC

Python Scripts to Generate Reports to Assist in Managing Apache Storm JIRA Issues

Hello everyone,

I just submitted a GitHub pull request<https://github.com/apache/storm/pull/627> (addressing STORM-931<https://issues.apache.org/jira/browse/STORM-931>) with the Python code that generates the report bellow. This patch is an extension of some scripts Bobby Evans developed earlier.

The motivation to create this report surfaced when searching for JIRA isues to work on. I noticed that we have several orphan GitHub pull requests (i.e. with bad or no JIRA IDs in their summary). Furthermore, a lot of JIRA issues that are marked as 'Open', i.e., not marked as 'In Progress’/'Reopened', already have GitHub pull requests, which means that a contributor is already working on them. This makes it challenging for newcomers to search for JIRA issues to work on, and for us to track our pending issues.

As one can see in the first four entries of the report, several items need action.

  *   GitHub pull requests with a bad JIRA ID should be assigned the correct JIRA ID
  *   GitHub pull requests without a JIRA ID should be assigned a JIRA ID
  *   GitHub pull requests that have +1 votes should be merged in and closed
  *   JIRA issues with ‘Open’ status, which already have a GitHub pull request, should be marked as 'In Progress'

I would like to suggest that we agree on the best way to take these actions. We can either reach out to the person that is working on each item that needs action and ask her/him to act, or one of us can volunteer to take the appropriate actions (e.g. mark the JIRA issues as 'In Progress’ - although it seems to me that JIRA will assign the issue to the person who marks it as in progress, and that person would have to reassign it back to the right person). I can volunteer to do this if we find that it is the best solution.

Another thing that could be useful is to track the ‘In Progress’ and ‘Reopened’ issues to identify if the person that started working on them is still working on them. We could update the script to track ‘In Progress’ issues that haven’t been updated in a long time (to define), and then check with the person if she/he is still working on it. This would allow us remark as 'Open’ tasks that may have been abandoned.


In order to keep the JIRA backlog up to date, we could run this report periodically. An option would be to have a periodically generated email sent to the dev@storm.apache.org<ma...@storm.apache.org> email list. I have also already started working on an script to generate the emails for us. Please let me know if you think this is a good way to go.


Looking forward to hearing your feedback and suggestions.

Thanks,

Best
Hugo

Report generated on: 2015-07-10 01:28:02 (GMT)

GITHUB PULL REQUESTS WITH BAD OR CLOSED JIRA ID (Count = 3)
URL                                        Title                                         Created   Last Updated (Days)   User
https://github.com/apache/storm/pull/611   [YSTORM-728] Put emitted and transferred...   8         8                     d2r
https://github.com/apache/storm/pull/449   STORM-694: java.lang.ClassNotFoundExcept...   132       101                   duke-bartholomew
https://github.com/apache/storm/pull/120   STORM-188: Allow user to specifiy full c...   414       100                   clockfly

GITHUB PULL REQUESTS WITHOUT A JIRA ID (Count = 26)
URL                                        Title                                         Created   Last Updated (Days)   User
https://github.com/apache/storm/pull/626   Fix links to documentation in Javadoc         0         0                     alexshadow007
https://github.com/apache/storm/pull/622   Fix a few links in the documentation          2         2                     thilinarmtb
https://github.com/apache/storm/pull/620   Added @Override annotation in sample cod...   4         4                     charleswhchan
https://github.com/apache/storm/pull/619   Cleanup extra ']' bracket in documentati...   4         4                     charleswhchan
https://github.com/apache/storm/pull/618   Update Maven documentation to storm-core...   4         4                     charleswhchan
https://github.com/apache/storm/pull/617   Storm 763/839 0.10.x                          6         5                     eshioji
https://github.com/apache/storm/pull/616   Storm 763/839 0.11.x                          6         6                     eshioji
https://github.com/apache/storm/pull/609   HiveBolt: Fix apache calcite dependency ...   9         2                     dossett
https://github.com/apache/storm/pull/599   Update pom.xml                                20        20                    vesense
https://github.com/apache/storm/pull/598   Update FluxBuilder.java - buildTopology(...   21        21                    lyonbrw
https://github.com/apache/storm/pull/584   Feature add topology based scheduler          31        31                    chuanlei
https://github.com/apache/storm/pull/583   In TestHiveBolt make the collector mock ...   32        17                    dossett
https://github.com/apache/storm/pull/582   Feature autotuning for max spout pending...   33        33                    chuanlei
https://github.com/apache/storm/pull/570   fix the dismatch between doc and code fo...   38        33                    chuanlei
https://github.com/apache/storm/pull/511   Update BYLAWS.md for clarification of co...   93        78                    knusbaum
https://github.com/apache/storm/pull/510   Add a convenience target to use when deb...   93        92                    l03wn3
https://github.com/apache/storm/pull/494   stormjar.jar on classpath first in super...   100       77                    emidln
https://github.com/apache/storm/pull/471   UserGroupInformation should use the same...   111       111                   onlychoice
https://github.com/apache/storm/pull/469   fastfix-01:Removed unused topology-path ...   112       98                    caofangkun
https://github.com/apache/storm/pull/460   added missing @Override annotations           123       62                    krichter722
https://github.com/apache/storm/pull/459   avoiding rawtypes in IBold.prepare in or...   123       123                   krichter722
https://github.com/apache/storm/pull/430   SimpleTransportPlugin Using TThreadPoolS...   147       115                   darionyaphet
https://github.com/apache/storm/pull/406   Kafka spout failure config                    157       2                     ogorun
https://github.com/apache/storm/pull/387   Storm 631: refactoring kafka connector c...   170       24                    Parth-Brahmbhatt
https://github.com/apache/storm/pull/341   Fix bug related to error handling in js ...   213       115                   anyatch
https://github.com/apache/storm/pull/335   Windows fork option                           219       115                   JamisonWhite

OPEN JIRA ISSUES THAT HAVE GITHUB PULL REQUESTS (Count = 42)
JIRA ID     Pull Request                               Jira Summary                                  JIRA Age   Pull Age   JIRA Update Age   Pull Update Age (Days)   JIRA Status   GitHub user
STORM-503   https://github.com/apache/storm/pull/625   Short disruptor queue wait time leads to...   290        0          0                 0                        Open          errordaiwa
STORM-928   https://github.com/apache/storm/pull/624   Add sources->streams->fields map to Mult...   2          2          1                 1                        Open          dan-blanchard
STORM-927   https://github.com/apache/storm/pull/623   Storm.cmd on Windows shouldn't exit unti...   2          2          2                 2                        Open          DevInsanity
STORM-926   https://github.com/apache/storm/pull/621   change pom to use maven-shade-plugin:2.2...   3          3          3                 3                        Open          caofangkun
STORM-913   https://github.com/apache/storm/pull/615   Use Curator's delete().deletingChildrenI...   13         6          6                 6                        Open          caofangkun
STORM-924   https://github.com/apache/storm/pull/614   Set the file mode of the files included ...   7          6          3                 3                        Open          caofangkun
STORM-919   https://github.com/apache/storm/pull/608   Gathering worker and supervisor process ...   9          9          3                 4                        Open          bourneagain
STORM-799   https://github.com/apache/storm/pull/607   Consolidate IErrorReporter and reportErr...   76         9          9                 9                        Open          dossett
STORM-914   https://github.com/apache/storm/pull/606   AutoHDFS should also update hdfs.config ...   13         13         0                 0                        Open          tedxia
STORM-917   https://github.com/apache/storm/pull/601   Ability to emit messages from a kafka sp...   12         16         10                10                       Open          anishek
STORM-903   https://github.com/apache/storm/pull/600   fix class missing when ui.filter set to ...   20         20         12                12                       Open          tedxia
STORM-874   https://github.com/apache/storm/pull/597   Netty Threads do not handle Errors prope...   21         21         16                16                       Open          kishorvpatil
STORM-67    https://github.com/apache/storm/pull/593   Provide API for spouts to know how many ...   572        27         3                 2                        Open          bourneagain
STORM-862   https://github.com/apache/storm/pull/589   Pluggable System Metrics                      29         29         23                23                       Open          revans2
STORM-859   https://github.com/apache/storm/pull/588   Add unit test to prevent regression of S...   29         29         10                10                       Open          HeartSaVioR
STORM-857   https://github.com/apache/storm/pull/586   Supervisor process fails to write log me...   30         30         17                17                       Open          d2r
STORM-160   https://github.com/apache/storm/pull/575   Allow ShellBolt to set env vars (particu...   571        36         3                 3                        Open          bourneagain
STORM-845   https://github.com/apache/storm/pull/573   Storm ElasticSearch connector                 37         36         16                16                       Open          sweetest
STORM-763   https://github.com/apache/storm/pull/568   nimbus reassigned worker A to another ma...   92         39         9                 9                        Open          eshioji
STORM-839   https://github.com/apache/storm/pull/566   Deadlock hazard in backtype.storm.messag...   42         41         6                 39                       Open          eshioji
STORM-831   https://github.com/apache/storm/pull/559   Add Jira and Central Logging URL to UI        50         50         43                43                       Open          kishorvpatil
STORM-820   https://github.com/apache/storm/pull/554   UI Topology & Component Pages have long ...   54         54         42                42                       Open          d2r
STORM-710   https://github.com/apache/storm/pull/553   bin/storm command list out all the class...   113        56         17                17                       Open          oleg03
STORM-436   https://github.com/apache/storm/pull/534   Clean up Clojure namespace declarations       338        76         71                58                       Open          danielcompton
STORM-768   https://github.com/apache/storm/pull/519   Support JDK 8 compile and runtime.            87         87         86                86                       Open          Lewuathe
STORM-733   https://github.com/apache/storm/pull/489   ShellBolts that don't respond to heartbe...   102        102        100               100                      Open          reembs
STORM-553   https://github.com/apache/storm/pull/478   Provide standard Java/Clojure Code Style...   240        107        90                90                       Open          caofangkun
STORM-468   https://github.com/apache/storm/pull/477   java.io.NotSerializableException should ...   320        107        107               107                      Open          jangie
STORM-720   https://github.com/apache/storm/pull/476   Storm.cmd should return ERRORLEVEL befor...   108        108        104               104                      Open          rtandonmsft
STORM-587   https://github.com/apache/storm/pull/475   trident transactional state in zk should...   215        108        105               105                      Open          harshach
STORM-695   https://github.com/apache/storm/pull/456   storm CLI tool reports zero exit code on...   132        127        112               112                      Open          Lewuathe
STORM-692   https://github.com/apache/storm/pull/447   KakfaSpout storage of offsets in Zookeep...   133        133        128               133                      Open          rmkellogg
STORM-671   https://github.com/apache/storm/pull/442   Measure tuple serialization/deserializat...   147        134        86                86                       Open          Lewuathe
STORM-702   https://github.com/apache/storm/pull/432   Apache Exhibitor support                      120        144        114               101                      Open          atdixon
STORM-590   https://github.com/apache/storm/pull/407   KafkaSpout should use kafka consumer api...   208        157        24                24                       Open          wurstmeister
STORM-166   https://github.com/apache/storm/pull/354   Highly available Nimbus                       571        202        107               105                      Open          Parth-Brahmbhatt
STORM-591   https://github.com/apache/storm/pull/352   logback.xml                                   207        202        24                24                       Open          Lewuathe
STORM-588   https://github.com/apache/storm/pull/346   Executor-Level Rebalance Mechanism            211        207        207               103                      Open          troyding
STORM-517   https://github.com/apache/storm/pull/281   Support for "-Dservice=" in bin/storm, v...   279        279        24                24                       Open          solarce
STORM-430   https://github.com/apache/storm/pull/250   (Security) Allow netty SASL to support e...   344        308        133               133                      Open          RaghavendraNandagopal
STORM-150   https://github.com/apache/storm/pull/71    Replace jar distribution strategy with b...   571        455        136               136                      Open          ptgoetz
STORM-166   https://github.com/apache/storm/pull/61    Highly available Nimbus                       571        461        107               274                      Open          yveschina

GITHUB PULL REQUESTS WITH VOTES FOR UNRESOLVED JIRAS (Count = 17)
JIRA ID     Pull Request                               Jira Summary                                  JIRA Age   Pull Age   JIRA Update Age   Pull Update Age (Days)   JIRA Status   GitHub user
Comment Vote    Comment Author    Pull URL                                    Comment Age

STORM-928   https://github.com/apache/storm/pull/624   Add sources->streams->fields map to Mult...   2          2          1                 1                        Open          dan-blanchard
+1              HeartSaVioR       https://github.com/apache/storm/pull/624    1

STORM-924   https://github.com/apache/storm/pull/614   Set the file mode of the files included ...   7          6          3                 3                        Open          caofangkun
+1              HeartSaVioR       https://github.com/apache/storm/pull/614    3

STORM-67    https://github.com/apache/storm/pull/593   Provide API for spouts to know how many ...   572        27         3                 2                        Open          bourneagain
-1              shyamrajendran    None                                        27

STORM-857   https://github.com/apache/storm/pull/586   Supervisor process fails to write log me...   30         30         17                17                       Open          d2r
+1              harshach          https://github.com/apache/storm/pull/586    17

STORM-160   https://github.com/apache/storm/pull/575   Allow ShellBolt to set env vars (particu...   571        36         3                 3                        Open          bourneagain
+1              HeartSaVioR       https://github.com/apache/storm/pull/575    3

STORM-763   https://github.com/apache/storm/pull/568   nimbus reassigned worker A to another ma...   92         39         9                 9                        Open          eshioji
+1              revans2           https://github.com/apache/storm/pull/568    38
-1              revans2           https://github.com/apache/storm/pull/568    37
+1              revans2           https://github.com/apache/storm/pull/568    13

STORM-839   https://github.com/apache/storm/pull/566   Deadlock hazard in backtype.storm.messag...   42         41         6                 39                       Open          eshioji
+1              Hailei            https://github.com/apache/storm/pull/566    41

STORM-831   https://github.com/apache/storm/pull/559   Add Jira and Central Logging URL to UI        50         50         43                43                       Open          kishorvpatil
+1              knusbaum          https://github.com/apache/storm/pull/559    44

STORM-820   https://github.com/apache/storm/pull/554   UI Topology & Component Pages have long ...   54         54         42                42                       Open          d2r
+1              knusbaum          https://github.com/apache/storm/pull/554    48

STORM-720   https://github.com/apache/storm/pull/476   Storm.cmd should return ERRORLEVEL befor...   108        108        104               104                      Open          rtandonmsft
+1              harshach          https://github.com/apache/storm/pull/476    104

STORM-587   https://github.com/apache/storm/pull/475   trident transactional state in zk should...   215        108        105               105                      Open          harshach
+1              Parth-Brahmbhatt  https://github.com/apache/storm/pull/475    107
-1              revans2           https://github.com/apache/storm/pull/475    105

STORM-695   https://github.com/apache/storm/pull/456   storm CLI tool reports zero exit code on...   132        127        112               112                      Open          Lewuathe
+0              miguno            None                                        132

STORM-671   https://github.com/apache/storm/pull/442   Measure tuple serialization/deserializat...   147        134        86                86                       Open          Lewuathe
+1              Parth-Brahmbhatt  https://github.com/apache/storm/pull/442    94
-1              nathanmarz        https://github.com/apache/storm/pull/442    86

STORM-702   https://github.com/apache/storm/pull/432   Apache Exhibitor support                      120        144        114               101                      Open          atdixon
+1              revans2           https://github.com/apache/storm/pull/432    114

STORM-658   https://github.com/apache/storm/pull/417   config topology.acker.executors default ...   154        154        15                147                      In Progress   caofangkun
-1              ptgoetz           https://github.com/apache/storm/pull/417    147

STORM-643   https://github.com/apache/storm/pull/405   KafkaUtils repeatedly fetches messages w...   158        157        80                80                       In Progress   vesense
+1              2new              https://github.com/apache/storm/pull/405    118

STORM-517   https://github.com/apache/storm/pull/281   Support for "-Dservice=" in bin/storm, v...   279        279        24                24                       Open          solarce
-1              nathanmarz        https://github.com/apache/storm/pull/281    278


IN PROGRESS OR REOPENED JIRA ISSUES THAT HAVE GITHUB PULL REQUESTS (Count = 13)
JIRA ID     Pull Request                               Jira Summary                                  JIRA Age   Pull Age   JIRA Update Age   Pull Update Age (Days)   JIRA Status   GitHub user
STORM-871   https://github.com/apache/storm/pull/602   Change multilang heartbeat mechanism to ...   22         16         0                 0                        In Progress   HeartSaVioR
STORM-817   https://github.com/apache/storm/pull/561   Kafka Wildcard Topic Support                  58         48         0                 0                        Reopened      sumitchawla
STORM-794   https://github.com/apache/storm/pull/542   Trident Topology with some situation see...   78         66         37                37                       In Progress   HeartSaVioR
STORM-756   https://github.com/apache/storm/pull/532   [multilang] Introduce overflow control m...   95         78         16                30                       In Progress   HeartSaVioR
STORM-742   https://github.com/apache/storm/pull/497   Very busy ShellBolt subprocess with ACK ...   100        100        16                37                       In Progress   HeartSaVioR
STORM-706   https://github.com/apache/storm/pull/465   Maven profile support for intelliJ            116        115        93                93                       In Progress   jayunit100
STORM-697   https://github.com/apache/storm/pull/454   Support for Emitting Kafka Message Offse...   129        128        58                54                       In Progress   mjtieman
STORM-668   https://github.com/apache/storm/pull/423    Generate storm-ui war using maven and d...   149        149        22                22                       In Progress   caofangkun
STORM-658   https://github.com/apache/storm/pull/417   config topology.acker.executors default ...   154        154        15                147                      In Progress   caofangkun
STORM-643   https://github.com/apache/storm/pull/405   KafkaUtils repeatedly fetches messages w...   158        157        80                80                       In Progress   vesense
STORM-638   https://github.com/apache/storm/pull/396   UI should show up  process-id of the Wor...   163        163        111               48                       In Progress   caofangkun
STORM-532   https://github.com/apache/storm/pull/296   Supervisor should restart worker immedia...   268        266        114               114                      In Progress   caofangkun
STORM-433   https://github.com/apache/storm/pull/236   Give users visibility to the depth of qu...   344        323        16                16                       In Progress   knusbaum

IN PROGRESS JIRA ISSUES (Count = 23)
Jira Id     Summary                                       Created   Last Updated (Days)
STORM-871   Change multilang heartbeat mechanism to ...   22        0
STORM-854   [Storm-Kafka] KafkaSpout can  set the to...   31        31
STORM-851   Storm Solr connector                          35        27
STORM-822   As a storm developer I’d like to use the...   52        52
STORM-794   Trident Topology with some situation see...   78        37
STORM-756   [multilang] Introduce overflow control m...   95        16
STORM-742   Very busy ShellBolt subprocess with ACK ...   100       16
STORM-718   Ip Clearence for JStorm related contribu...   108       72
STORM-706   Maven profile support for intelliJ            116       93
STORM-701   provide eclipse plugin for creating/moni...   120       113
STORM-697   Support for Emitting Kafka Message Offse...   129       58
STORM-668    Generate storm-ui war using maven and d...   149       22
STORM-658   config topology.acker.executors default ...   154       15
STORM-643   KafkaUtils repeatedly fetches messages w...   158       80
STORM-638   UI should show up  process-id of the Wor...   163       111
STORM-628   Storm-HBase add support to WriteBuffer/s...   175       17
STORM-619   add supervisor page to show workers runn...   181       181
STORM-532   Supervisor should restart worker immedia...   268       114
STORM-528   examples/storm-starter/multilang/resourc...   271       143
STORM-462   Find a way to only have one copy of stor...   324       171
STORM-433   Give users visibility to the depth of qu...   344       16
STORM-429   Document Storm vs. Spark Streaming            345       80
STORM-385   Clojure code examples not displaying wit...   372       171

OPEN JIRA ISSUES THAT DON'T HAVE GITHUB PULL REQUESTS (Count = 339)
Jira Id     Summary                                       Created   Last Updated (Days)
STORM-930   Nimbus server shutting down                   0         0
STORM-925   Move DefaultRolloverStrategy in log4j2/w...   6         6
STORM-923   (Security) Add AutoHDFS like credential ...   8         8
STORM-922   Storm-Core Dependencies Renamed in Shade...   8         8
STORM-921   Create unit tests for worker-worker nett...   9         8
STORM-920   Should we  remove duplicated classes/cod...   9         9
STORM-918   Storm CLI could validate arguments/print...   10        10
STORM-916   test-noop-authorization-w-simple-transpo...   13        13
STORM-915   Track and resolve any further random tes...   13        13
STORM-911   Have nimbus request resources from and r...   14        14
STORM-909   Automatic Black Listing of bad nodes          15        15
STORM-908   AWS workers can't communicate due to Net...   15        10
STORM-907   More Intellegent Backpressure                 15        15
STORM-906   Flux "--local --zookeeper" dose not work...   15        15
STORM-905   Look into supporting Cloud Dataflow stre...   16        16
STORM-904   move storm bin commands to java and prov...   17        0
STORM-902   Simple Log Search                             20        20
STORM-901   Worker Artifacts Directory                    20        20
STORM-900   Provide Metrics Feedback API to Resource...   20        20
STORM-899   CPU/Memory/Network metrics collection         20        20
STORM-898   Add priorities and per user resource gua...   20        20
STORM-897   Add Multi-tenant scheduler as a resource...   20        20
STORM-896   Make Resource Aware strategy configurabl...   20        20
STORM-895   Explore different Resource Aware schedul...   20        20
STORM-894   Basic Resource Aware Scheduling               20        20
STORM-893   Resource Aware Scheduling                     20        20
STORM-892   Worker Metrics Collection Improvements        20        20
STORM-891   Should we have one JVM per bolt/spout?        21        21
STORM-890   Should we move the worker to java?            21        21
STORM-889   Worker Performance Optimizations              21        20
STORM-888   Nimbus Scaling: very large topologies         21        21
STORM-887   Nimbus Scaling: Thousands of topologies       21        21
STORM-886   Automatic Back Pressure                       21        21
STORM-885   Heartbeat Server (Pacemaker)                  21        8
STORM-884   Dist Cache: don't let blobstore users re...   21        21
STORM-883   Dist Cache: Have supervisor throttle dow...   21        21
STORM-882   Dist Cache: Have HDFS blob store downloa...   21        21
STORM-881   Dist Cache: Randomize the order of blobs...   21        21
STORM-880   Dist Cache: allow files already in HDFS ...   21        21
STORM-879   Dist Cache: Quota/Usage Metrics Support       21        21
STORM-878   Dist Cache: UI Displays current version ...   21        21
STORM-877   Dist Cache: Worker API to know when blob...   21        21
STORM-876   Dist Cache: Basic Functionality               21        21
STORM-872   Expose interfaces to give users opportun...   22        21
STORM-869   kafka spout cannot fetch message if log ...   23        23
STORM-865   Reflection in send path                       28        28
STORM-863   UI report TTransportException                 28        28
STORM-855   Add tuple batching                            31        24
STORM-846   ShellBolt throws java.lang.RuntimeExcept...   36        36
STORM-844   [storm-redis] access modifier for fields...   38        38
STORM-840   My supervisor crashes when I kill a topo...   41        13
STORM-838   Upgrade Jackson                               42        42
STORM-837   HdfsState ignores commits                     44        42
STORM-836   DPRC request failed after DRPC server re...   44        44
STORM-834   Class cast exception Object to Iterable       46        29
STORM-832   Validation for configuration settings be...   49        49
STORM-829   Hadoop dependency confusion                   51        51
STORM-828   HdfsBolt takes a lot of configuration, n...   51        51
STORM-825   As a storm developer I’d like consistent...   52        52
STORM-824   As a storm developer I’d like all logger...   52        52
STORM-823   As a storm developer I’d like to use ITu...   52        52
STORM-819   output fields/emit mismatch from a multi...   57        57
STORM-815   Auto tuning topologies based on user sub...   58        17
STORM-812   Create Testing#createLocalCluster             60        60
STORM-805   Supervisor crashes with 'org.apache.comm...   71        17
STORM-804   HdfsBolt doesn't work after a period of ...   71        71
STORM-802   Multilang tests throw NoOutputException ...   72        72
STORM-798   storm-kafka tests are failing intermitte...   77        31
STORM-793   Logviewer 500 response when metadata has...   79        55
STORM-785   Have UI know about trident and display t...   85        85
STORM-784   Trident Docs: javadoc and markdown for b...   85        85
STORM-783   Trident Docs: javadoc for operations          85        85
STORM-782   Trident Docs: javadoc for IBackingMap         85        85
STORM-781   Trident Docs: javadoc MemoryMapState          85        85
STORM-780   Trident Docs: javadoc for IPartitionedTr...   85        85
STORM-779   Trident Docs: javadoc for IOpaquePartiti...   85        85
STORM-778   Trident Docs: javadoc for ITridentSpout       85        85
STORM-777   Trident Docs: debugging                       85        85
STORM-776   Trident Docs: Tuning and Optimizations        85        85
STORM-775   Trident Docs: commits and coord               85        85
STORM-774   Improve Trident Documentation                 85        85
STORM-770   NullPointerException in consumeBatchToCu...   86        13
STORM-769   Storm can not identify JAVA_HOME if the ...   86        38
STORM-759   Storm target for waiting for remote java...   93        93
STORM-758   Very busy ShellBolt subprocess with Non-...   94        16
STORM-755   An exception occured while executing the...   95        94
STORM-751   Move javadoc aggregate to site phase.         97        95
STORM-744   downstream worker fail may lead to worke...   98        98
STORM-743   Invalid JSON produced when serializing T...   99        99
STORM-739   If a worker dies supervisor clears local...   100       100
STORM-738   Multilang needs Overflow-Control mechani...   100       16
STORM-737   Workers may try to send to closed connec...   101       41
STORM-736   Add a RESTful API to  print all of the t...   101       101
STORM-734   When ShellBolt dies it calls System.exit...   102       102
STORM-732   PartitionManager should remove those mes...   103       49
STORM-726   Adding nimbus.host config for backward c...   105       105
STORM-725   Topology does not start                       106       106
STORM-717   Proposal: JStorm contribution from Aliba...   108       14
STORM-716   Change Storm Package Names                    108       100
STORM-709   Received unexpected tuple                     114       87
STORM-705   Add BigPetStore stream to examples/           118       117
STORM-700   Add a hint about auto-generation in java...   122       122
STORM-698   Jackson incompatibility ring-json             127       122
STORM-679   Enforce JDK 1.7 for storm-kafka               140       134
STORM-677   Maximum retries strategy may cause data ...   141       139
STORM-676   Storm Trident support sliding windows         141       141
STORM-674   Add chaos monkey testing to storm             142       142
STORM-666   Create a CONTRIBUTING file which explain...   150       150
STORM-665   Lower entry barrier for understanding st...   150       117
STORM-664   Link to inexisting wiki on documentation...   150       150
STORM-662   java.lang.OutOfMemoryError: Direct buffe...   150       150
STORM-660    IndexOutOfBoundsException with  shuffle...   151       150
STORM-655   Ad replication count as part of topology...   156       156
STORM-654   Create a thrift API to discover nimbus s...   156       147
STORM-650   Storm-Kafka Refactoring and Improvements...   157       28
STORM-642   Add Storm Benchmarking Framework              160       160
STORM-639   storm-maven-plugin not found                  160       97
STORM-631   Simplifying kafka connector code              170       157
STORM-621   UI should expose more version informatio...   178       178
STORM-618    Add spoutconfig option to make kafka sp...   182       36
STORM-617   In Storm secure mode re-deploying triden...   184       108
STORM-605   Attempting to call unbound fn during bol...   196       16
STORM-602   HdfsBolt dies when the hadoop node is no...   198       24
STORM-597   spout not receve the message acker            200       200
STORM-594   Auto-Scaling Resources in a Topology          206       15
STORM-589   Suboptimal default worker hb timeouts fo...   211       211
STORM-584   LoggingMetricsConsumer metrics.log file ...   216       146
STORM-580   Tunnel logviewer through nimbus so publi...   220       220
STORM-579   Trident KafkaSpout throws RunTimeExcepti...   221       221
STORM-576   Random "Clojure failed" message               224       178
STORM-566   Unexpected trident spout metadata serial...   231       231
STORM-564   Support worker use dynamic port               231       224
STORM-562   When Isolated topologies are running "fr...   232       230
STORM-551   Will be better if Use "storm.conf.dir"  ...   240       240
STORM-545   DRCP does not return a cause of failure       248       148
STORM-542   Topology summary executors/workers count...   256       35
STORM-536   java.lang.NoClassDefFoundError: org/apac...   263       263
STORM-526   Nimbus triggered complete removal of all...   272       272
STORM-522   NullPointerException in storm.kafka.ZkCo...   275       275
STORM-521   UI: No way of telling easily that tuples...   275       148
STORM-520   Using storm.local.hostname causes bolts ...   275       275
STORM-518   subprocess.py not found while executing ...   276       276
STORM-516   Thrift source files in storm-core.jar re...   280       280
STORM-515   Clojure documentation and examples            280       148
STORM-510   Netty messaging client blocks transfer t...   286       115
STORM-491   (Security) Security Enhancements Break S...   304       281
STORM-484   Implement topology validation logic in T...   309       309
STORM-481   A specific trident topology pattern caus...   314       314
STORM-467   storm jar executes non-existant or old j...   320       318
STORM-465   Hook API for Trident Operations               323       323
STORM-459   multilang seems had read from pipe but d...   326       325
STORM-452   Update link to Perl multilang implementa...   331       319
STORM-440   NimbusClient throws NPE if Config.STORM_...   338       336
STORM-438   SimpleACLAuthorizer should allow users w...   338       337
STORM-432   Enable version-agnostic serialization of...   344       332
STORM-431   Topology back pressure using netty trans...   344       344
STORM-425   Storm Integration with YARN Timeline Ser...   349       349
STORM-423   Allow a SpoutConfig to specify to begin ...   350       350
STORM-418   using storm kafka spout doesn't scale wh...   351       350
STORM-416   Allow user defined system streams             352       352
STORM-413   Investigate Tests using Simulated Time a...   357       357
STORM-412   Allow users to modify logging levels of ...   357       101
STORM-411   Extend file uploads to support more dist...   357       21
STORM-409   (Security) add groups authorization supp...   357       302
STORM-408   Cross-Site Scripting security vulnerabil...   357       328
STORM-394   Messages has expired, OFFSET_OUT_OF_RANG...   366       49
STORM-392   Implement WhiteList topics for KafkaSpou...   367       49
STORM-389   Wrong default wait time when killing a t...   367       367
STORM-383   Test time-outs when running metrics_test...   373       373
STORM-374   storm0.9.1&kafka0.8.1 with storm-kafka-0...   377       377
STORM-371   Windows support to run workers as user        380       380
STORM-368   Trident groupBy().aggregate() produces n...   380       380
STORM-362   Update version requirement for clojure/t...   385       366
STORM-353   Add configuration per kafka-bolt              388       385
STORM-340   Add topology submission REST API and UI ...   399       213
STORM-339   Severe memory leak to OOM when ackers di...   399       367
STORM-333   Kryo Serializers not threadsafe               408       408
STORM-327   command-line interface  for Storm and pr...   415       415
STORM-324   Require notes on internal of storm            418       318
STORM-314   Storm breaks tools.cli upgrades on Cloju...   428       148
STORM-300   Add need_task_ids field to the multilang...   439       148
STORM-293   Relatime Topologies Time interval             442       442
STORM-292   emit blocks the publishing bolt if disru...   443       441
STORM-284   Priority in streams                           449       449
STORM-283   Support for config_value, running storm ...   450       414
STORM-278   Storm on Windows: Modifications required...   458       449
STORM-261   Workers should commit suicide if not sch...   475       472
STORM-257   Need to harvest doc from old GitHub issu...   479       479
STORM-256   storm relanace bug caused supervisor mis...   485       336
STORM-255   supervisor shutdown worker bug Cause wok...   485       482
STORM-253   Allow worker to choose available port in...   491       149
STORM-250   Storm UI: Too many open files                 492       489
STORM-249   Activate not called in trident.spout.Ric...   496       496
STORM-240   Make the Juju Charm for Storm work great...   511       499
STORM-230   Validate Topology Size                        517       51
STORM-215   Document How to Replace Netty Transport ...   518       104
STORM-212   Add storm-jms as a module                     526       526
STORM-209   Add storm-cassandra as a module               526       526
STORM-206   Incorporate "Contrib" Modules into Apach...   526       526
STORM-204   Local topologies that throw exceptions c...   527       527
STORM-203   Add /usr/lib64 in default java library p...   527       526
STORM-202   Worker can possibly hang when the stdout...   527       517
STORM-201   JAVA Home should be read from current JV...   527       527
STORM-199   Move off of Custom Thrift for Code Gener...   528       528
STORM-197   registering metrics in an IRichSpout use...   539       471
STORM-193   I think it would be more user friendly i...   545       539
STORM-179   integration testing of custom serializer...   568       568
STORM-178   sending metrics to Ganglia                    569       181
STORM-177   Add cpu metrics                               571       568
STORM-176   UI will lead to wrong url when running s...   571       240
STORM-175    Wokers should extend supervisor’s confi...   571       571
STORM-174   Implement DBMetricsConsumer  to store Me...   571       569
STORM-172   Add hooks for creating shared resources ...   571       571
STORM-171   Add "progress" method to OutputCollector...   571       571
STORM-170   serialize all storm zk state as EDN           571       332
STORM-169   Storm depends on outdated versions of hi...   571       100
STORM-168   Serialization of spouts/bolts                 571       571
STORM-167   proposal for storm topology online updat...   571       41
STORM-165   Adding more supervisor causes topology (...   571       571
STORM-164   Split Storm into multiple modules             571       571
STORM-163   Simulated Cluster Time doesn't work well...   571       378
STORM-161   Proposal: move the Kryo config code out ...   571       472
STORM-158   Live tracing of tuples through the flow       571       571
STORM-157   ack/fail should not require keeping inpu...   571       571
STORM-154   Provide more information to spout "fail"...   571       571
STORM-152   Permissions of resources are not preserv...   571       571
STORM-151   Support multilang in Trident                  571       199
STORM-148   Track Nimbus actions in UI                    571       349
STORM-147   UI should use metrics framework               571       571
STORM-145   worker and supervisor heartbeat to nimbu...   571       571
STORM-144   Provide visibiilty into buffers between ...   571       571
STORM-143   Launching a process throws away standard...   571       517
STORM-142   Errors during deserialization of spouts/...   571       571
STORM-141   Provide support for custom stats in Stor...   571       571
STORM-140   Provide unique working directory to each...   571       571
STORM-139   hashCode does not work for byte[]             571       571
STORM-137   add new feature: "topology package"           571       571
STORM-136   [Trident] Bug when working with two spou...   571       148
STORM-135   Tracer bullets                                571       571
STORM-133   FileNotFoundException during supervisor ...   571       571
STORM-131   Intermittent Zookeper errors when shutti...   571       378
STORM-129   Keep Storm dependencies and user depende...   571       146
STORM-128   Topology fails to start if a configured ...   571       571
STORM-126   Add Lifecycle support API for worker nod...   571       343
STORM-124   Tuple Lost in Trident Topology on Remote...   571       571
STORM-123   NImbus BCP                                    571       571
STORM-122   log4j-over-slf4j in 0.9.0-rc2 breaks exi...   571       471
STORM-121   A hook should be able to modify a tuple       571       571
STORM-120   util/acquire-random-range-id is not thre...   571       37
STORM-119   Nimbus and Supervisor process crash with...   571       571
STORM-118   Docs: Minor typo in transactional-commit...   571       571
STORM-117   Storm should provide client library           572       13
STORM-116   [UI] Sort bolt/spout in order that wrote...   572       572
STORM-115   Allow bin/storm to take a config as a pa...   572       535
STORM-114   Runtime ClassCastException while attempt...   572       572
STORM-112   Race condition between Topology Kill and...   572       204
STORM-111   Corrupt worker heartbeat on server reboo...   572       572
STORM-109   Deploying topology with 540 workers caus...   572       572
STORM-108   Add commit support to Trident Transactio...   572       572
STORM-107   Add better ways to construct topologies       572       161
STORM-105   storm.py should turn off sysout to avoid...   572       572
STORM-104   Debugging exceptions where the workers d...   572       517
STORM-103   Notify spout nodes from within the topol...   572       572
STORM-102   Nimbus service throws unchecked Runtime ...   572       572
STORM-101   Merging two streams with the same fields...   572       572
STORM-100   MultiReducerProcessor should pass the co...   572       572
STORM-98    .stateQuery twice halts tuple execution?...   572       572
STORM-97    Setting custom log levels per topology        572       343
STORM-96    _msgIdToBatchId in RichSpoutBatchTrigger...   572       572
STORM-94    Extend QueryFunction API to support pagi...   572       572
STORM-93    Storm UI breaks when proxied                  572       572
STORM-92    storm should permit storing configuratio...   572       572
STORM-91    Registering already registered serializa...   572       572
STORM-90     Make it possible to use the ShellBolt w...   572       572
STORM-89    Can't use more complex types in the topo...   572       572
STORM-88    ICommitterTridentSpout.commit can't fail...   572       572
STORM-85    IsolationScheduler fails due to NoSuchEl...   572       572
STORM-84    Don't use hashCode for fields grouping        572       572
STORM-83    zeromq send can cause divide by 0 in mul...   572       572
STORM-82    Please support settings for changing the...   572       572
STORM-81    BUG: In local topology, ShellSpout attem...   572       546
STORM-80    NPE caused by TridentBoltExecutor reusin...   572       572
STORM-79    Don't use Java serialization for storing...   572       332
STORM-78    Storm UI Needs HTTP Auth                      572       517
STORM-77    Nimbus should ignore topologies for whic...   572       572
STORM-74    LocalDRPC.execute never returns after ti...   572       572
STORM-73    TridentTopology with a RichSpout and tup...   572       572
STORM-71    java.util.Date isn't serializable.            572       413
STORM-68    Need multiple output streams for a bolt ...   572       572
STORM-64    Add Handshake when establishing new conn...   572       572
STORM-62    Update Jetty to latest version                572       572
STORM-61    Compatibility matrix                          572       572
STORM-60    Document Thrift APIs                          572       148
STORM-59    Support status messages on Storm UI           572       572
STORM-58    Provide worker pids via Thrift API            572       572
STORM-57    Make Storm handle ByteBuffers as fields ...   572       148
STORM-56    Provide support for handling "bad data"       572       572
STORM-55    Replace Storm's scheduler with a constra...   572       572
STORM-53    Add interface and StateUpdater for appen...   572       572
STORM-52    Implement DRPC futures                        572       572
STORM-51    DRPC client pool                              572       542
STORM-50    Refactor DRPC logic                           574       574
STORM-49    Make State implement Closeable                574       574
STORM-48    Storm may not work with IPv6                  574       574
STORM-47    add TopologyContext#getNimbusClient           574       574
STORM-46    Allow scheduler to configure memory per ...   574       125
STORM-45    Stateful bolts                                574       538
STORM-44    Replication                                   574       574
STORM-43    Detect and kill blocked tasks                 574       574
STORM-42    Support sending arbitrary data types bac...   574       549
STORM-41    show worker's working directory in storm...   574       574
STORM-40    Turn worker GC logging on by default          574       574
STORM-39    Expose number of attempts for a batch wi...   574       574
STORM-38    Should be able to do state updates throu...   574       574
STORM-37    Auto-deactivate topologies that are cont...   574       574
STORM-36    partitionPersist that can take as input ...   574       574
STORM-34    Check that same version of Storm used du...   574       574
STORM-33    Log warning if number of un-acked tuples...   574       574
STORM-31    Auto-tune max spout pending                   574       574
STORM-30    Modularized Storm artifacts for using St...   574       574
STORM-28    DRPCClient should support connection poo...   574       574
STORM-27    Expose add-supervisor via Java testing A...   574       574
STORM-26    Bound serialization buffers                   574       574
STORM-25    Trident should track number of tuples in...   574       574
STORM-24    Refactor internal routing to more effici...   574       574
STORM-23    Spouts should track nextTuple latency         574       574
STORM-22    Expose stream metadata via TridentOperat...   574       414
STORM-21    Provide metrics on the size of serialize...   574       574
STORM-20    Add API for controlling the parallelism ...   574       574
STORM-19    Trident operations should be able to reg...   574       574
STORM-18    Trident sections connected by a merge sh...   574       574
STORM-17    Spouts should be their own ackers             574       574
STORM-16    Better logging when worker slots are con...   574       574
STORM-15    Storm UI should measure distribution of ...   574       574
STORM-11    Want the ability to deactivate specific ...   575       575
STORM-10    Exception when tick tuples are enabled o...   575       575
STORM-9     Add test utilities for Trident topology       575       575
STORM-8     deactivate command is not work with IPar...   575       575
STORM-7     storm.trident.operation.Aggregator: incl...   575       575




Re: Python Scripts to Generate Reports to Assist in Managing Apache Storm JIRA Issues

Posted by "Aaron.Dossett" <Aa...@target.com>.
I am relatively new to the project, but I think these are all great ideas.
 One comment though: the contribution guide does encourage people to skip
the JIRA step for small changes and go straight to a PR. Presumably many
PRs with no JIRA fall into this category. (some of my open PRs do :-)

https://storm.apache.org/documentation/Contributing-to-Storm.html


On 7/9/15, 9:59 PM, "Hugo Louro" <hl...@hortonworks.com> wrote:

>Hello everyone,
>
>I just submitted a GitHub pull
>request<https://github.com/apache/storm/pull/627> (addressing
>STORM-931<https://issues.apache.org/jira/browse/STORM-931>) with the
>Python code that generates the report bellow. This patch is an extension
>of some scripts Bobby Evans developed earlier.
>
>The motivation to create this report surfaced when searching for JIRA
>isues to work on. I noticed that we have several orphan GitHub pull
>requests (i.e. with bad or no JIRA IDs in their summary). Furthermore, a
>lot of JIRA issues that are marked as 'Open', i.e., not marked as 'In
>Progress¹/'Reopened', already have GitHub pull requests, which means that
>a contributor is already working on them. This makes it challenging for
>newcomers to search for JIRA issues to work on, and for us to track our
>pending issues.
>
>As one can see in the first four entries of the report, several items
>need action.
>
>  *   GitHub pull requests with a bad JIRA ID should be assigned the
>correct JIRA ID
>  *   GitHub pull requests without a JIRA ID should be assigned a JIRA ID
>  *   GitHub pull requests that have +1 votes should be merged in and
>closed
>  *   JIRA issues with ŒOpen¹ status, which already have a GitHub pull
>request, should be marked as 'In Progress'
>
>I would like to suggest that we agree on the best way to take these
>actions. We can either reach out to the person that is working on each
>item that needs action and ask her/him to act, or one of us can volunteer
>to take the appropriate actions (e.g. mark the JIRA issues as 'In
>Progress¹ - although it seems to me that JIRA will assign the issue to
>the person who marks it as in progress, and that person would have to
>reassign it back to the right person). I can volunteer to do this if we
>find that it is the best solution.
>
>Another thing that could be useful is to track the ŒIn Progress¹ and
>ŒReopened¹ issues to identify if the person that started working on them
>is still working on them. We could update the script to track ŒIn
>Progress¹ issues that haven¹t been updated in a long time (to define),
>and then check with the person if she/he is still working on it. This
>would allow us remark as 'Open¹ tasks that may have been abandoned.
>
>
>In order to keep the JIRA backlog up to date, we could run this report
>periodically. An option would be to have a periodically generated email
>sent to the dev@storm.apache.org<ma...@storm.apache.org> email list.
>I have also already started working on an script to generate the emails
>for us. Please let me know if you think this is a good way to go.
>
>
>Looking forward to hearing your feedback and suggestions.
>
>Thanks,
>
>Best
>Hugo
>
>Report generated on: 2015-07-10 01:28:02 (GMT)
>
>GITHUB PULL REQUESTS WITH BAD OR CLOSED JIRA ID (Count = 3)
>URL                                        Title
>               Created   Last Updated (Days)   User
>https://github.com/apache/storm/pull/611   [YSTORM-728] Put emitted and
>transferred...   8         8                     d2r
>https://github.com/apache/storm/pull/449   STORM-694:
>java.lang.ClassNotFoundExcept...   132       101
>duke-bartholomew
>https://github.com/apache/storm/pull/120   STORM-188: Allow user to
>specifiy full c...   414       100                   clockfly
>
>GITHUB PULL REQUESTS WITHOUT A JIRA ID (Count = 26)
>URL                                        Title
>               Created   Last Updated (Days)   User
>https://github.com/apache/storm/pull/626   Fix links to documentation in
>Javadoc         0         0                     alexshadow007
>https://github.com/apache/storm/pull/622   Fix a few links in the
>documentation          2         2                     thilinarmtb
>https://github.com/apache/storm/pull/620   Added @Override annotation in
>sample cod...   4         4                     charleswhchan
>https://github.com/apache/storm/pull/619   Cleanup extra ']' bracket in
>documentati...   4         4                     charleswhchan
>https://github.com/apache/storm/pull/618   Update Maven documentation to
>storm-core...   4         4                     charleswhchan
>https://github.com/apache/storm/pull/617   Storm 763/839 0.10.x
>               6         5                     eshioji
>https://github.com/apache/storm/pull/616   Storm 763/839 0.11.x
>               6         6                     eshioji
>https://github.com/apache/storm/pull/609   HiveBolt: Fix apache calcite
>dependency ...   9         2                     dossett
>https://github.com/apache/storm/pull/599   Update pom.xml
>               20        20                    vesense
>https://github.com/apache/storm/pull/598   Update FluxBuilder.java -
>buildTopology(...   21        21                    lyonbrw
>https://github.com/apache/storm/pull/584   Feature add topology based
>scheduler          31        31                    chuanlei
>https://github.com/apache/storm/pull/583   In TestHiveBolt make the
>collector mock ...   32        17                    dossett
>https://github.com/apache/storm/pull/582   Feature autotuning for max
>spout pending...   33        33                    chuanlei
>https://github.com/apache/storm/pull/570   fix the dismatch between doc
>and code fo...   38        33                    chuanlei
>https://github.com/apache/storm/pull/511   Update BYLAWS.md for
>clarification of co...   93        78                    knusbaum
>https://github.com/apache/storm/pull/510   Add a convenience target to
>use when deb...   93        92                    l03wn3
>https://github.com/apache/storm/pull/494   stormjar.jar on classpath
>first in super...   100       77                    emidln
>https://github.com/apache/storm/pull/471   UserGroupInformation should
>use the same...   111       111                   onlychoice
>https://github.com/apache/storm/pull/469   fastfix-01:Removed unused
>topology-path ...   112       98                    caofangkun
>https://github.com/apache/storm/pull/460   added missing @Override
>annotations           123       62                    krichter722
>https://github.com/apache/storm/pull/459   avoiding rawtypes in
>IBold.prepare in or...   123       123                   krichter722
>https://github.com/apache/storm/pull/430   SimpleTransportPlugin Using
>TThreadPoolS...   147       115                   darionyaphet
>https://github.com/apache/storm/pull/406   Kafka spout failure config
>               157       2                     ogorun
>https://github.com/apache/storm/pull/387   Storm 631: refactoring kafka
>connector c...   170       24                    Parth-Brahmbhatt
>https://github.com/apache/storm/pull/341   Fix bug related to error
>handling in js ...   213       115                   anyatch
>https://github.com/apache/storm/pull/335   Windows fork option
>               219       115                   JamisonWhite
>
>OPEN JIRA ISSUES THAT HAVE GITHUB PULL REQUESTS (Count = 42)
>JIRA ID     Pull Request                               Jira Summary
>                           JIRA Age   Pull Age   JIRA Update Age   Pull
>Update Age (Days)   JIRA Status   GitHub user
>STORM-503   https://github.com/apache/storm/pull/625   Short disruptor
>queue wait time leads to...   290        0          0                 0
>                     Open          errordaiwa
>STORM-928   https://github.com/apache/storm/pull/624   Add
>sources->streams->fields map to Mult...   2          2          1
>        1                        Open          dan-blanchard
>STORM-927   https://github.com/apache/storm/pull/623   Storm.cmd on
>Windows shouldn't exit unti...   2          2          2
>2                        Open          DevInsanity
>STORM-926   https://github.com/apache/storm/pull/621   change pom to use
>maven-shade-plugin:2.2...   3          3          3                 3
>                   Open          caofangkun
>STORM-913   https://github.com/apache/storm/pull/615   Use Curator's
>delete().deletingChildrenI...   13         6          6                 6
>                       Open          caofangkun
>STORM-924   https://github.com/apache/storm/pull/614   Set the file mode
>of the files included ...   7          6          3                 3
>                   Open          caofangkun
>STORM-919   https://github.com/apache/storm/pull/608   Gathering worker
>and supervisor process ...   9          9          3                 4
>                    Open          bourneagain
>STORM-799   https://github.com/apache/storm/pull/607   Consolidate
>IErrorReporter and reportErr...   76         9          9
>9                        Open          dossett
>STORM-914   https://github.com/apache/storm/pull/606   AutoHDFS should
>also update hdfs.config ...   13         13         0                 0
>                     Open          tedxia
>STORM-917   https://github.com/apache/storm/pull/601   Ability to emit
>messages from a kafka sp...   12         16         10                10
>                     Open          anishek
>STORM-903   https://github.com/apache/storm/pull/600   fix class missing
>when ui.filter set to ...   20         20         12                12
>                   Open          tedxia
>STORM-874   https://github.com/apache/storm/pull/597   Netty Threads do
>not handle Errors prope...   21         21         16                16
>                    Open          kishorvpatil
>STORM-67    https://github.com/apache/storm/pull/593   Provide API for
>spouts to know how many ...   572        27         3                 2
>                     Open          bourneagain
>STORM-862   https://github.com/apache/storm/pull/589   Pluggable System
>Metrics                      29         29         23                23
>                    Open          revans2
>STORM-859   https://github.com/apache/storm/pull/588   Add unit test to
>prevent regression of S...   29         29         10                10
>                    Open          HeartSaVioR
>STORM-857   https://github.com/apache/storm/pull/586   Supervisor process
>fails to write log me...   30         30         17                17
>                  Open          d2r
>STORM-160   https://github.com/apache/storm/pull/575   Allow ShellBolt to
>set env vars (particu...   571        36         3                 3
>                  Open          bourneagain
>STORM-845   https://github.com/apache/storm/pull/573   Storm
>ElasticSearch connector                 37         36         16
>      16                       Open          sweetest
>STORM-763   https://github.com/apache/storm/pull/568   nimbus reassigned
>worker A to another ma...   92         39         9                 9
>                   Open          eshioji
>STORM-839   https://github.com/apache/storm/pull/566   Deadlock hazard in
>backtype.storm.messag...   42         41         6                 39
>                  Open          eshioji
>STORM-831   https://github.com/apache/storm/pull/559   Add Jira and
>Central Logging URL to UI        50         50         43
>43                       Open          kishorvpatil
>STORM-820   https://github.com/apache/storm/pull/554   UI Topology &
>Component Pages have long ...   54         54         42
>42                       Open          d2r
>STORM-710   https://github.com/apache/storm/pull/553   bin/storm command
>list out all the class...   113        56         17                17
>                   Open          oleg03
>STORM-436   https://github.com/apache/storm/pull/534   Clean up Clojure
>namespace declarations       338        76         71                58
>                    Open          danielcompton
>STORM-768   https://github.com/apache/storm/pull/519   Support JDK 8
>compile and runtime.            87         87         86
>86                       Open          Lewuathe
>STORM-733   https://github.com/apache/storm/pull/489   ShellBolts that
>don't respond to heartbe...   102        102        100               100
>                     Open          reembs
>STORM-553   https://github.com/apache/storm/pull/478   Provide standard
>Java/Clojure Code Style...   240        107        90                90
>                    Open          caofangkun
>STORM-468   https://github.com/apache/storm/pull/477
>java.io.NotSerializableException should ...   320        107        107
>            107                      Open          jangie
>STORM-720   https://github.com/apache/storm/pull/476   Storm.cmd should
>return ERRORLEVEL befor...   108        108        104               104
>                    Open          rtandonmsft
>STORM-587   https://github.com/apache/storm/pull/475   trident
>transactional state in zk should...   215        108        105
>    105                      Open          harshach
>STORM-695   https://github.com/apache/storm/pull/456   storm CLI tool
>reports zero exit code on...   132        127        112
>112                      Open          Lewuathe
>STORM-692   https://github.com/apache/storm/pull/447   KakfaSpout storage
>of offsets in Zookeep...   133        133        128               133
>                  Open          rmkellogg
>STORM-671   https://github.com/apache/storm/pull/442   Measure tuple
>serialization/deserializat...   147        134        86
>86                       Open          Lewuathe
>STORM-702   https://github.com/apache/storm/pull/432   Apache Exhibitor
>support                      120        144        114               101
>                    Open          atdixon
>STORM-590   https://github.com/apache/storm/pull/407   KafkaSpout should
>use kafka consumer api...   208        157        24                24
>                   Open          wurstmeister
>STORM-166   https://github.com/apache/storm/pull/354   Highly available
>Nimbus                       571        202        107               105
>                    Open          Parth-Brahmbhatt
>STORM-591   https://github.com/apache/storm/pull/352   logback.xml
>                           207        202        24                24
>                  Open          Lewuathe
>STORM-588   https://github.com/apache/storm/pull/346   Executor-Level
>Rebalance Mechanism            211        207        207
>103                      Open          troyding
>STORM-517   https://github.com/apache/storm/pull/281   Support for
>"-Dservice=" in bin/storm, v...   279        279        24
>24                       Open          solarce
>STORM-430   https://github.com/apache/storm/pull/250   (Security) Allow
>netty SASL to support e...   344        308        133               133
>                    Open          RaghavendraNandagopal
>STORM-150   https://github.com/apache/storm/pull/71    Replace jar
>distribution strategy with b...   571        455        136
>136                      Open          ptgoetz
>STORM-166   https://github.com/apache/storm/pull/61    Highly available
>Nimbus                       571        461        107               274
>                    Open          yveschina
>
>GITHUB PULL REQUESTS WITH VOTES FOR UNRESOLVED JIRAS (Count = 17)
>JIRA ID     Pull Request                               Jira Summary
>                           JIRA Age   Pull Age   JIRA Update Age   Pull
>Update Age (Days)   JIRA Status   GitHub user
>Comment Vote    Comment Author    Pull URL
>    Comment Age
>
>STORM-928   https://github.com/apache/storm/pull/624   Add
>sources->streams->fields map to Mult...   2          2          1
>        1                        Open          dan-blanchard
>+1              HeartSaVioR
>https://github.com/apache/storm/pull/624    1
>
>STORM-924   https://github.com/apache/storm/pull/614   Set the file mode
>of the files included ...   7          6          3                 3
>                   Open          caofangkun
>+1              HeartSaVioR
>https://github.com/apache/storm/pull/614    3
>
>STORM-67    https://github.com/apache/storm/pull/593   Provide API for
>spouts to know how many ...   572        27         3                 2
>                     Open          bourneagain
>-1              shyamrajendran    None
>    27
>
>STORM-857   https://github.com/apache/storm/pull/586   Supervisor process
>fails to write log me...   30         30         17                17
>                  Open          d2r
>+1              harshach
>https://github.com/apache/storm/pull/586    17
>
>STORM-160   https://github.com/apache/storm/pull/575   Allow ShellBolt to
>set env vars (particu...   571        36         3                 3
>                  Open          bourneagain
>+1              HeartSaVioR
>https://github.com/apache/storm/pull/575    3
>
>STORM-763   https://github.com/apache/storm/pull/568   nimbus reassigned
>worker A to another ma...   92         39         9                 9
>                   Open          eshioji
>+1              revans2
>https://github.com/apache/storm/pull/568    38
>-1              revans2
>https://github.com/apache/storm/pull/568    37
>+1              revans2
>https://github.com/apache/storm/pull/568    13
>
>STORM-839   https://github.com/apache/storm/pull/566   Deadlock hazard in
>backtype.storm.messag...   42         41         6                 39
>                  Open          eshioji
>+1              Hailei
>https://github.com/apache/storm/pull/566    41
>
>STORM-831   https://github.com/apache/storm/pull/559   Add Jira and
>Central Logging URL to UI        50         50         43
>43                       Open          kishorvpatil
>+1              knusbaum
>https://github.com/apache/storm/pull/559    44
>
>STORM-820   https://github.com/apache/storm/pull/554   UI Topology &
>Component Pages have long ...   54         54         42
>42                       Open          d2r
>+1              knusbaum
>https://github.com/apache/storm/pull/554    48
>
>STORM-720   https://github.com/apache/storm/pull/476   Storm.cmd should
>return ERRORLEVEL befor...   108        108        104               104
>                    Open          rtandonmsft
>+1              harshach
>https://github.com/apache/storm/pull/476    104
>
>STORM-587   https://github.com/apache/storm/pull/475   trident
>transactional state in zk should...   215        108        105
>    105                      Open          harshach
>+1              Parth-Brahmbhatt
>https://github.com/apache/storm/pull/475    107
>-1              revans2
>https://github.com/apache/storm/pull/475    105
>
>STORM-695   https://github.com/apache/storm/pull/456   storm CLI tool
>reports zero exit code on...   132        127        112
>112                      Open          Lewuathe
>+0              miguno            None
>    132
>
>STORM-671   https://github.com/apache/storm/pull/442   Measure tuple
>serialization/deserializat...   147        134        86
>86                       Open          Lewuathe
>+1              Parth-Brahmbhatt
>https://github.com/apache/storm/pull/442    94
>-1              nathanmarz
>https://github.com/apache/storm/pull/442    86
>
>STORM-702   https://github.com/apache/storm/pull/432   Apache Exhibitor
>support                      120        144        114               101
>                    Open          atdixon
>+1              revans2
>https://github.com/apache/storm/pull/432    114
>
>STORM-658   https://github.com/apache/storm/pull/417   config
>topology.acker.executors default ...   154        154        15
>     147                      In Progress   caofangkun
>-1              ptgoetz
>https://github.com/apache/storm/pull/417    147
>
>STORM-643   https://github.com/apache/storm/pull/405   KafkaUtils
>repeatedly fetches messages w...   158        157        80
> 80                       In Progress   vesense
>+1              2new
>https://github.com/apache/storm/pull/405    118
>
>STORM-517   https://github.com/apache/storm/pull/281   Support for
>"-Dservice=" in bin/storm, v...   279        279        24
>24                       Open          solarce
>-1              nathanmarz
>https://github.com/apache/storm/pull/281    278
>
>
>IN PROGRESS OR REOPENED JIRA ISSUES THAT HAVE GITHUB PULL REQUESTS (Count
>= 13)
>JIRA ID     Pull Request                               Jira Summary
>                           JIRA Age   Pull Age   JIRA Update Age   Pull
>Update Age (Days)   JIRA Status   GitHub user
>STORM-871   https://github.com/apache/storm/pull/602   Change multilang
>heartbeat mechanism to ...   22         16         0                 0
>                    In Progress   HeartSaVioR
>STORM-817   https://github.com/apache/storm/pull/561   Kafka Wildcard
>Topic Support                  58         48         0                 0
>                      Reopened      sumitchawla
>STORM-794   https://github.com/apache/storm/pull/542   Trident Topology
>with some situation see...   78         66         37                37
>                    In Progress   HeartSaVioR
>STORM-756   https://github.com/apache/storm/pull/532   [multilang]
>Introduce overflow control m...   95         78         16
>30                       In Progress   HeartSaVioR
>STORM-742   https://github.com/apache/storm/pull/497   Very busy
>ShellBolt subprocess with ACK ...   100        100        16
>  37                       In Progress   HeartSaVioR
>STORM-706   https://github.com/apache/storm/pull/465   Maven profile
>support for intelliJ            116        115        93
>93                       In Progress   jayunit100
>STORM-697   https://github.com/apache/storm/pull/454   Support for
>Emitting Kafka Message Offse...   129        128        58
>54                       In Progress   mjtieman
>STORM-668   https://github.com/apache/storm/pull/423    Generate storm-ui
>war using maven and d...   149        149        22                22
>                  In Progress   caofangkun
>STORM-658   https://github.com/apache/storm/pull/417   config
>topology.acker.executors default ...   154        154        15
>     147                      In Progress   caofangkun
>STORM-643   https://github.com/apache/storm/pull/405   KafkaUtils
>repeatedly fetches messages w...   158        157        80
> 80                       In Progress   vesense
>STORM-638   https://github.com/apache/storm/pull/396   UI should show up
>process-id of the Wor...   163        163        111               48
>                  In Progress   caofangkun
>STORM-532   https://github.com/apache/storm/pull/296   Supervisor should
>restart worker immedia...   268        266        114               114
>                   In Progress   caofangkun
>STORM-433   https://github.com/apache/storm/pull/236   Give users
>visibility to the depth of qu...   344        323        16
> 16                       In Progress   knusbaum
>
>IN PROGRESS JIRA ISSUES (Count = 23)
>Jira Id     Summary                                       Created   Last
>Updated (Days)
>STORM-871   Change multilang heartbeat mechanism to ...   22        0
>STORM-854   [Storm-Kafka] KafkaSpout can  set the to...   31        31
>STORM-851   Storm Solr connector                          35        27
>STORM-822   As a storm developer I¹d like to use the...   52        52
>STORM-794   Trident Topology with some situation see...   78        37
>STORM-756   [multilang] Introduce overflow control m...   95        16
>STORM-742   Very busy ShellBolt subprocess with ACK ...   100       16
>STORM-718   Ip Clearence for JStorm related contribu...   108       72
>STORM-706   Maven profile support for intelliJ            116       93
>STORM-701   provide eclipse plugin for creating/moni...   120       113
>STORM-697   Support for Emitting Kafka Message Offse...   129       58
>STORM-668    Generate storm-ui war using maven and d...   149       22
>STORM-658   config topology.acker.executors default ...   154       15
>STORM-643   KafkaUtils repeatedly fetches messages w...   158       80
>STORM-638   UI should show up  process-id of the Wor...   163       111
>STORM-628   Storm-HBase add support to WriteBuffer/s...   175       17
>STORM-619   add supervisor page to show workers runn...   181       181
>STORM-532   Supervisor should restart worker immedia...   268       114
>STORM-528   examples/storm-starter/multilang/resourc...   271       143
>STORM-462   Find a way to only have one copy of stor...   324       171
>STORM-433   Give users visibility to the depth of qu...   344       16
>STORM-429   Document Storm vs. Spark Streaming            345       80
>STORM-385   Clojure code examples not displaying wit...   372       171
>
>OPEN JIRA ISSUES THAT DON'T HAVE GITHUB PULL REQUESTS (Count = 339)
>Jira Id     Summary                                       Created   Last
>Updated (Days)
>STORM-930   Nimbus server shutting down                   0         0
>STORM-925   Move DefaultRolloverStrategy in log4j2/w...   6         6
>STORM-923   (Security) Add AutoHDFS like credential ...   8         8
>STORM-922   Storm-Core Dependencies Renamed in Shade...   8         8
>STORM-921   Create unit tests for worker-worker nett...   9         8
>STORM-920   Should we  remove duplicated classes/cod...   9         9
>STORM-918   Storm CLI could validate arguments/print...   10        10
>STORM-916   test-noop-authorization-w-simple-transpo...   13        13
>STORM-915   Track and resolve any further random tes...   13        13
>STORM-911   Have nimbus request resources from and r...   14        14
>STORM-909   Automatic Black Listing of bad nodes          15        15
>STORM-908   AWS workers can't communicate due to Net...   15        10
>STORM-907   More Intellegent Backpressure                 15        15
>STORM-906   Flux "--local --zookeeper" dose not work...   15        15
>STORM-905   Look into supporting Cloud Dataflow stre...   16        16
>STORM-904   move storm bin commands to java and prov...   17        0
>STORM-902   Simple Log Search                             20        20
>STORM-901   Worker Artifacts Directory                    20        20
>STORM-900   Provide Metrics Feedback API to Resource...   20        20
>STORM-899   CPU/Memory/Network metrics collection         20        20
>STORM-898   Add priorities and per user resource gua...   20        20
>STORM-897   Add Multi-tenant scheduler as a resource...   20        20
>STORM-896   Make Resource Aware strategy configurabl...   20        20
>STORM-895   Explore different Resource Aware schedul...   20        20
>STORM-894   Basic Resource Aware Scheduling               20        20
>STORM-893   Resource Aware Scheduling                     20        20
>STORM-892   Worker Metrics Collection Improvements        20        20
>STORM-891   Should we have one JVM per bolt/spout?        21        21
>STORM-890   Should we move the worker to java?            21        21
>STORM-889   Worker Performance Optimizations              21        20
>STORM-888   Nimbus Scaling: very large topologies         21        21
>STORM-887   Nimbus Scaling: Thousands of topologies       21        21
>STORM-886   Automatic Back Pressure                       21        21
>STORM-885   Heartbeat Server (Pacemaker)                  21        8
>STORM-884   Dist Cache: don't let blobstore users re...   21        21
>STORM-883   Dist Cache: Have supervisor throttle dow...   21        21
>STORM-882   Dist Cache: Have HDFS blob store downloa...   21        21
>STORM-881   Dist Cache: Randomize the order of blobs...   21        21
>STORM-880   Dist Cache: allow files already in HDFS ...   21        21
>STORM-879   Dist Cache: Quota/Usage Metrics Support       21        21
>STORM-878   Dist Cache: UI Displays current version ...   21        21
>STORM-877   Dist Cache: Worker API to know when blob...   21        21
>STORM-876   Dist Cache: Basic Functionality               21        21
>STORM-872   Expose interfaces to give users opportun...   22        21
>STORM-869   kafka spout cannot fetch message if log ...   23        23
>STORM-865   Reflection in send path                       28        28
>STORM-863   UI report TTransportException                 28        28
>STORM-855   Add tuple batching                            31        24
>STORM-846   ShellBolt throws java.lang.RuntimeExcept...   36        36
>STORM-844   [storm-redis] access modifier for fields...   38        38
>STORM-840   My supervisor crashes when I kill a topo...   41        13
>STORM-838   Upgrade Jackson                               42        42
>STORM-837   HdfsState ignores commits                     44        42
>STORM-836   DPRC request failed after DRPC server re...   44        44
>STORM-834   Class cast exception Object to Iterable       46        29
>STORM-832   Validation for configuration settings be...   49        49
>STORM-829   Hadoop dependency confusion                   51        51
>STORM-828   HdfsBolt takes a lot of configuration, n...   51        51
>STORM-825   As a storm developer I¹d like consistent...   52        52
>STORM-824   As a storm developer I¹d like all logger...   52        52
>STORM-823   As a storm developer I¹d like to use ITu...   52        52
>STORM-819   output fields/emit mismatch from a multi...   57        57
>STORM-815   Auto tuning topologies based on user sub...   58        17
>STORM-812   Create Testing#createLocalCluster             60        60
>STORM-805   Supervisor crashes with 'org.apache.comm...   71        17
>STORM-804   HdfsBolt doesn't work after a period of ...   71        71
>STORM-802   Multilang tests throw NoOutputException ...   72        72
>STORM-798   storm-kafka tests are failing intermitte...   77        31
>STORM-793   Logviewer 500 response when metadata has...   79        55
>STORM-785   Have UI know about trident and display t...   85        85
>STORM-784   Trident Docs: javadoc and markdown for b...   85        85
>STORM-783   Trident Docs: javadoc for operations          85        85
>STORM-782   Trident Docs: javadoc for IBackingMap         85        85
>STORM-781   Trident Docs: javadoc MemoryMapState          85        85
>STORM-780   Trident Docs: javadoc for IPartitionedTr...   85        85
>STORM-779   Trident Docs: javadoc for IOpaquePartiti...   85        85
>STORM-778   Trident Docs: javadoc for ITridentSpout       85        85
>STORM-777   Trident Docs: debugging                       85        85
>STORM-776   Trident Docs: Tuning and Optimizations        85        85
>STORM-775   Trident Docs: commits and coord               85        85
>STORM-774   Improve Trident Documentation                 85        85
>STORM-770   NullPointerException in consumeBatchToCu...   86        13
>STORM-769   Storm can not identify JAVA_HOME if the ...   86        38
>STORM-759   Storm target for waiting for remote java...   93        93
>STORM-758   Very busy ShellBolt subprocess with Non-...   94        16
>STORM-755   An exception occured while executing the...   95        94
>STORM-751   Move javadoc aggregate to site phase.         97        95
>STORM-744   downstream worker fail may lead to worke...   98        98
>STORM-743   Invalid JSON produced when serializing T...   99        99
>STORM-739   If a worker dies supervisor clears local...   100       100
>STORM-738   Multilang needs Overflow-Control mechani...   100       16
>STORM-737   Workers may try to send to closed connec...   101       41
>STORM-736   Add a RESTful API to  print all of the t...   101       101
>STORM-734   When ShellBolt dies it calls System.exit...   102       102
>STORM-732   PartitionManager should remove those mes...   103       49
>STORM-726   Adding nimbus.host config for backward c...   105       105
>STORM-725   Topology does not start                       106       106
>STORM-717   Proposal: JStorm contribution from Aliba...   108       14
>STORM-716   Change Storm Package Names                    108       100
>STORM-709   Received unexpected tuple                     114       87
>STORM-705   Add BigPetStore stream to examples/           118       117
>STORM-700   Add a hint about auto-generation in java...   122       122
>STORM-698   Jackson incompatibility ring-json             127       122
>STORM-679   Enforce JDK 1.7 for storm-kafka               140       134
>STORM-677   Maximum retries strategy may cause data ...   141       139
>STORM-676   Storm Trident support sliding windows         141       141
>STORM-674   Add chaos monkey testing to storm             142       142
>STORM-666   Create a CONTRIBUTING file which explain...   150       150
>STORM-665   Lower entry barrier for understanding st...   150       117
>STORM-664   Link to inexisting wiki on documentation...   150       150
>STORM-662   java.lang.OutOfMemoryError: Direct buffe...   150       150
>STORM-660    IndexOutOfBoundsException with  shuffle...   151       150
>STORM-655   Ad replication count as part of topology...   156       156
>STORM-654   Create a thrift API to discover nimbus s...   156       147
>STORM-650   Storm-Kafka Refactoring and Improvements...   157       28
>STORM-642   Add Storm Benchmarking Framework              160       160
>STORM-639   storm-maven-plugin not found                  160       97
>STORM-631   Simplifying kafka connector code              170       157
>STORM-621   UI should expose more version informatio...   178       178
>STORM-618    Add spoutconfig option to make kafka sp...   182       36
>STORM-617   In Storm secure mode re-deploying triden...   184       108
>STORM-605   Attempting to call unbound fn during bol...   196       16
>STORM-602   HdfsBolt dies when the hadoop node is no...   198       24
>STORM-597   spout not receve the message acker            200       200
>STORM-594   Auto-Scaling Resources in a Topology          206       15
>STORM-589   Suboptimal default worker hb timeouts fo...   211       211
>STORM-584   LoggingMetricsConsumer metrics.log file ...   216       146
>STORM-580   Tunnel logviewer through nimbus so publi...   220       220
>STORM-579   Trident KafkaSpout throws RunTimeExcepti...   221       221
>STORM-576   Random "Clojure failed" message               224       178
>STORM-566   Unexpected trident spout metadata serial...   231       231
>STORM-564   Support worker use dynamic port               231       224
>STORM-562   When Isolated topologies are running "fr...   232       230
>STORM-551   Will be better if Use "storm.conf.dir"  ...   240       240
>STORM-545   DRCP does not return a cause of failure       248       148
>STORM-542   Topology summary executors/workers count...   256       35
>STORM-536   java.lang.NoClassDefFoundError: org/apac...   263       263
>STORM-526   Nimbus triggered complete removal of all...   272       272
>STORM-522   NullPointerException in storm.kafka.ZkCo...   275       275
>STORM-521   UI: No way of telling easily that tuples...   275       148
>STORM-520   Using storm.local.hostname causes bolts ...   275       275
>STORM-518   subprocess.py not found while executing ...   276       276
>STORM-516   Thrift source files in storm-core.jar re...   280       280
>STORM-515   Clojure documentation and examples            280       148
>STORM-510   Netty messaging client blocks transfer t...   286       115
>STORM-491   (Security) Security Enhancements Break S...   304       281
>STORM-484   Implement topology validation logic in T...   309       309
>STORM-481   A specific trident topology pattern caus...   314       314
>STORM-467   storm jar executes non-existant or old j...   320       318
>STORM-465   Hook API for Trident Operations               323       323
>STORM-459   multilang seems had read from pipe but d...   326       325
>STORM-452   Update link to Perl multilang implementa...   331       319
>STORM-440   NimbusClient throws NPE if Config.STORM_...   338       336
>STORM-438   SimpleACLAuthorizer should allow users w...   338       337
>STORM-432   Enable version-agnostic serialization of...   344       332
>STORM-431   Topology back pressure using netty trans...   344       344
>STORM-425   Storm Integration with YARN Timeline Ser...   349       349
>STORM-423   Allow a SpoutConfig to specify to begin ...   350       350
>STORM-418   using storm kafka spout doesn't scale wh...   351       350
>STORM-416   Allow user defined system streams             352       352
>STORM-413   Investigate Tests using Simulated Time a...   357       357
>STORM-412   Allow users to modify logging levels of ...   357       101
>STORM-411   Extend file uploads to support more dist...   357       21
>STORM-409   (Security) add groups authorization supp...   357       302
>STORM-408   Cross-Site Scripting security vulnerabil...   357       328
>STORM-394   Messages has expired, OFFSET_OUT_OF_RANG...   366       49
>STORM-392   Implement WhiteList topics for KafkaSpou...   367       49
>STORM-389   Wrong default wait time when killing a t...   367       367
>STORM-383   Test time-outs when running metrics_test...   373       373
>STORM-374   storm0.9.1&kafka0.8.1 with storm-kafka-0...   377       377
>STORM-371   Windows support to run workers as user        380       380
>STORM-368   Trident groupBy().aggregate() produces n...   380       380
>STORM-362   Update version requirement for clojure/t...   385       366
>STORM-353   Add configuration per kafka-bolt              388       385
>STORM-340   Add topology submission REST API and UI ...   399       213
>STORM-339   Severe memory leak to OOM when ackers di...   399       367
>STORM-333   Kryo Serializers not threadsafe               408       408
>STORM-327   command-line interface  for Storm and pr...   415       415
>STORM-324   Require notes on internal of storm            418       318
>STORM-314   Storm breaks tools.cli upgrades on Cloju...   428       148
>STORM-300   Add need_task_ids field to the multilang...   439       148
>STORM-293   Relatime Topologies Time interval             442       442
>STORM-292   emit blocks the publishing bolt if disru...   443       441
>STORM-284   Priority in streams                           449       449
>STORM-283   Support for config_value, running storm ...   450       414
>STORM-278   Storm on Windows: Modifications required...   458       449
>STORM-261   Workers should commit suicide if not sch...   475       472
>STORM-257   Need to harvest doc from old GitHub issu...   479       479
>STORM-256   storm relanace bug caused supervisor mis...   485       336
>STORM-255   supervisor shutdown worker bug Cause wok...   485       482
>STORM-253   Allow worker to choose available port in...   491       149
>STORM-250   Storm UI: Too many open files                 492       489
>STORM-249   Activate not called in trident.spout.Ric...   496       496
>STORM-240   Make the Juju Charm for Storm work great...   511       499
>STORM-230   Validate Topology Size                        517       51
>STORM-215   Document How to Replace Netty Transport ...   518       104
>STORM-212   Add storm-jms as a module                     526       526
>STORM-209   Add storm-cassandra as a module               526       526
>STORM-206   Incorporate "Contrib" Modules into Apach...   526       526
>STORM-204   Local topologies that throw exceptions c...   527       527
>STORM-203   Add /usr/lib64 in default java library p...   527       526
>STORM-202   Worker can possibly hang when the stdout...   527       517
>STORM-201   JAVA Home should be read from current JV...   527       527
>STORM-199   Move off of Custom Thrift for Code Gener...   528       528
>STORM-197   registering metrics in an IRichSpout use...   539       471
>STORM-193   I think it would be more user friendly i...   545       539
>STORM-179   integration testing of custom serializer...   568       568
>STORM-178   sending metrics to Ganglia                    569       181
>STORM-177   Add cpu metrics                               571       568
>STORM-176   UI will lead to wrong url when running s...   571       240
>STORM-175    Wokers should extend supervisor¹s confi...   571       571
>STORM-174   Implement DBMetricsConsumer  to store Me...   571       569
>STORM-172   Add hooks for creating shared resources ...   571       571
>STORM-171   Add "progress" method to OutputCollector...   571       571
>STORM-170   serialize all storm zk state as EDN           571       332
>STORM-169   Storm depends on outdated versions of hi...   571       100
>STORM-168   Serialization of spouts/bolts                 571       571
>STORM-167   proposal for storm topology online updat...   571       41
>STORM-165   Adding more supervisor causes topology (...   571       571
>STORM-164   Split Storm into multiple modules             571       571
>STORM-163   Simulated Cluster Time doesn't work well...   571       378
>STORM-161   Proposal: move the Kryo config code out ...   571       472
>STORM-158   Live tracing of tuples through the flow       571       571
>STORM-157   ack/fail should not require keeping inpu...   571       571
>STORM-154   Provide more information to spout "fail"...   571       571
>STORM-152   Permissions of resources are not preserv...   571       571
>STORM-151   Support multilang in Trident                  571       199
>STORM-148   Track Nimbus actions in UI                    571       349
>STORM-147   UI should use metrics framework               571       571
>STORM-145   worker and supervisor heartbeat to nimbu...   571       571
>STORM-144   Provide visibiilty into buffers between ...   571       571
>STORM-143   Launching a process throws away standard...   571       517
>STORM-142   Errors during deserialization of spouts/...   571       571
>STORM-141   Provide support for custom stats in Stor...   571       571
>STORM-140   Provide unique working directory to each...   571       571
>STORM-139   hashCode does not work for byte[]             571       571
>STORM-137   add new feature: "topology package"           571       571
>STORM-136   [Trident] Bug when working with two spou...   571       148
>STORM-135   Tracer bullets                                571       571
>STORM-133   FileNotFoundException during supervisor ...   571       571
>STORM-131   Intermittent Zookeper errors when shutti...   571       378
>STORM-129   Keep Storm dependencies and user depende...   571       146
>STORM-128   Topology fails to start if a configured ...   571       571
>STORM-126   Add Lifecycle support API for worker nod...   571       343
>STORM-124   Tuple Lost in Trident Topology on Remote...   571       571
>STORM-123   NImbus BCP                                    571       571
>STORM-122   log4j-over-slf4j in 0.9.0-rc2 breaks exi...   571       471
>STORM-121   A hook should be able to modify a tuple       571       571
>STORM-120   util/acquire-random-range-id is not thre...   571       37
>STORM-119   Nimbus and Supervisor process crash with...   571       571
>STORM-118   Docs: Minor typo in transactional-commit...   571       571
>STORM-117   Storm should provide client library           572       13
>STORM-116   [UI] Sort bolt/spout in order that wrote...   572       572
>STORM-115   Allow bin/storm to take a config as a pa...   572       535
>STORM-114   Runtime ClassCastException while attempt...   572       572
>STORM-112   Race condition between Topology Kill and...   572       204
>STORM-111   Corrupt worker heartbeat on server reboo...   572       572
>STORM-109   Deploying topology with 540 workers caus...   572       572
>STORM-108   Add commit support to Trident Transactio...   572       572
>STORM-107   Add better ways to construct topologies       572       161
>STORM-105   storm.py should turn off sysout to avoid...   572       572
>STORM-104   Debugging exceptions where the workers d...   572       517
>STORM-103   Notify spout nodes from within the topol...   572       572
>STORM-102   Nimbus service throws unchecked Runtime ...   572       572
>STORM-101   Merging two streams with the same fields...   572       572
>STORM-100   MultiReducerProcessor should pass the co...   572       572
>STORM-98    .stateQuery twice halts tuple execution?...   572       572
>STORM-97    Setting custom log levels per topology        572       343
>STORM-96    _msgIdToBatchId in RichSpoutBatchTrigger...   572       572
>STORM-94    Extend QueryFunction API to support pagi...   572       572
>STORM-93    Storm UI breaks when proxied                  572       572
>STORM-92    storm should permit storing configuratio...   572       572
>STORM-91    Registering already registered serializa...   572       572
>STORM-90     Make it possible to use the ShellBolt w...   572       572
>STORM-89    Can't use more complex types in the topo...   572       572
>STORM-88    ICommitterTridentSpout.commit can't fail...   572       572
>STORM-85    IsolationScheduler fails due to NoSuchEl...   572       572
>STORM-84    Don't use hashCode for fields grouping        572       572
>STORM-83    zeromq send can cause divide by 0 in mul...   572       572
>STORM-82    Please support settings for changing the...   572       572
>STORM-81    BUG: In local topology, ShellSpout attem...   572       546
>STORM-80    NPE caused by TridentBoltExecutor reusin...   572       572
>STORM-79    Don't use Java serialization for storing...   572       332
>STORM-78    Storm UI Needs HTTP Auth                      572       517
>STORM-77    Nimbus should ignore topologies for whic...   572       572
>STORM-74    LocalDRPC.execute never returns after ti...   572       572
>STORM-73    TridentTopology with a RichSpout and tup...   572       572
>STORM-71    java.util.Date isn't serializable.            572       413
>STORM-68    Need multiple output streams for a bolt ...   572       572
>STORM-64    Add Handshake when establishing new conn...   572       572
>STORM-62    Update Jetty to latest version                572       572
>STORM-61    Compatibility matrix                          572       572
>STORM-60    Document Thrift APIs                          572       148
>STORM-59    Support status messages on Storm UI           572       572
>STORM-58    Provide worker pids via Thrift API            572       572
>STORM-57    Make Storm handle ByteBuffers as fields ...   572       148
>STORM-56    Provide support for handling "bad data"       572       572
>STORM-55    Replace Storm's scheduler with a constra...   572       572
>STORM-53    Add interface and StateUpdater for appen...   572       572
>STORM-52    Implement DRPC futures                        572       572
>STORM-51    DRPC client pool                              572       542
>STORM-50    Refactor DRPC logic                           574       574
>STORM-49    Make State implement Closeable                574       574
>STORM-48    Storm may not work with IPv6                  574       574
>STORM-47    add TopologyContext#getNimbusClient           574       574
>STORM-46    Allow scheduler to configure memory per ...   574       125
>STORM-45    Stateful bolts                                574       538
>STORM-44    Replication                                   574       574
>STORM-43    Detect and kill blocked tasks                 574       574
>STORM-42    Support sending arbitrary data types bac...   574       549
>STORM-41    show worker's working directory in storm...   574       574
>STORM-40    Turn worker GC logging on by default          574       574
>STORM-39    Expose number of attempts for a batch wi...   574       574
>STORM-38    Should be able to do state updates throu...   574       574
>STORM-37    Auto-deactivate topologies that are cont...   574       574
>STORM-36    partitionPersist that can take as input ...   574       574
>STORM-34    Check that same version of Storm used du...   574       574
>STORM-33    Log warning if number of un-acked tuples...   574       574
>STORM-31    Auto-tune max spout pending                   574       574
>STORM-30    Modularized Storm artifacts for using St...   574       574
>STORM-28    DRPCClient should support connection poo...   574       574
>STORM-27    Expose add-supervisor via Java testing A...   574       574
>STORM-26    Bound serialization buffers                   574       574
>STORM-25    Trident should track number of tuples in...   574       574
>STORM-24    Refactor internal routing to more effici...   574       574
>STORM-23    Spouts should track nextTuple latency         574       574
>STORM-22    Expose stream metadata via TridentOperat...   574       414
>STORM-21    Provide metrics on the size of serialize...   574       574
>STORM-20    Add API for controlling the parallelism ...   574       574
>STORM-19    Trident operations should be able to reg...   574       574
>STORM-18    Trident sections connected by a merge sh...   574       574
>STORM-17    Spouts should be their own ackers             574       574
>STORM-16    Better logging when worker slots are con...   574       574
>STORM-15    Storm UI should measure distribution of ...   574       574
>STORM-11    Want the ability to deactivate specific ...   575       575
>STORM-10    Exception when tick tuples are enabled o...   575       575
>STORM-9     Add test utilities for Trident topology       575       575
>STORM-8     deactivate command is not work with IPar...   575       575
>STORM-7     storm.trident.operation.Aggregator: incl...   575       575
>
>
>