Uploaded image for project: 'Flink'
  1. Flink
  2. FLINK-7369

Add more information for `Key group index out of range of key group range` exception

    XMLWordPrintableJSON

Details

    • Improvement
    • Status: Closed
    • Major
    • Resolution: Fixed
    • None
    • 1.4.0
    • Runtime / Task
    • None

    Description

      When i got the following exception log, it make me confused that the index is more than `32` or less than `16`. So, we should add more information for it.

      ```java
      java.lang.IllegalArgumentException: Key group index out of range of key group range [16, 32).
      at org.apache.flink.runtime.state.heap.NestedMapsStateTable.setMapForKeyGroup(NestedMapsStateTable.java:104)
      at org.apache.flink.runtime.state.heap.NestedMapsStateTable.putAndGetOld(NestedMapsStateTable.java:218)
      at org.apache.flink.runtime.state.heap.NestedMapsStateTable.put(NestedMapsStateTable.java:207)
      at org.apache.flink.runtime.state.heap.NestedMapsStateTable.put(NestedMapsStateTable.java:145)
      at org.apache.flink.runtime.state.heap.HeapValueState.update(HeapValueState.java:72)
      at org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator.updateNFA(AbstractKeyedCEPPatternOperator.java:276)
      at org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator.processElement(AbstractKeyedCEPPatternOperator.java:171)
      at org.apache.flink.streaming.runtime.io.StreamInputProcessor.processInput(StreamInputProcessor.java:206)
      at org.apache.flink.streaming.runtime.tasks.OneInputStreamTask.run(OneInputStreamTask.java:69)
      at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:263)
      at org.apache.flink.runtime.taskmanager.Task.run(Task.java:702)
      at java.lang.Thread.run(Thread.java:745)
      ```

      Attachments

        Issue Links

          Activity

            People

              benedict jin Benedict Jin
              benedict jin Benedict Jin
              Votes:
              0 Vote for this issue
              Watchers:
              3 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: