Class ExecutionContextImpl

    • Constructor Detail

      • ExecutionContextImpl

        public ExecutionContextImpl​(org.apache.flink.streaming.api.operators.AbstractStreamOperator<?> operator,
                                    org.apache.flink.api.common.functions.RuntimeContext runtimeContext)
    • Method Detail

      • currentKey

        public org.apache.flink.table.data.RowData currentKey()
        Specified by:
        currentKey in interface ExecutionContext
        Returns:
        key of the current processed element.
      • getRuntimeContext

        public org.apache.flink.api.common.functions.RuntimeContext getRuntimeContext()
        Specified by:
        getRuntimeContext in interface ExecutionContext