Class PatternSelectAdapter<IN,​OUT>

    • Method Detail

      • open

        public void open​(org.apache.flink.api.common.functions.OpenContext openContext)
                  throws Exception
        Specified by:
        open in interface org.apache.flink.api.common.functions.RichFunction
        Overrides:
        open in class org.apache.flink.api.common.functions.AbstractRichFunction
        Throws:
        Exception
      • close

        public void close()
                   throws Exception
        Specified by:
        close in interface org.apache.flink.api.common.functions.RichFunction
        Overrides:
        close in class org.apache.flink.api.common.functions.AbstractRichFunction
        Throws:
        Exception
      • processMatch

        public void processMatch​(Map<String,​List<IN>> match,
                                 PatternProcessFunction.Context ctx,
                                 org.apache.flink.util.Collector<OUT> out)
                          throws Exception
        Description copied from class: PatternProcessFunction
        Generates resulting elements given a map of detected pattern events. The events are identified by their specified names.

        TimeContext.timestamp() in this case returns the time of the last element that was assigned to the match, resulting in this partial match being finished.

        Specified by:
        processMatch in class PatternProcessFunction<IN,​OUT>
        Parameters:
        match - map containing the found pattern. Events are identified by their names.
        ctx - enables access to time features and emitting results through side outputs
        out - Collector used to output the generated elements
        Throws:
        Exception - This method may throw exceptions. Throwing an exception will cause the operation to fail and may trigger recovery.