Uses of Interface
org.apache.flink.runtime.operators.TaskContext
-
Packages that use TaskContext Package Description org.apache.flink.runtime.iterative.task org.apache.flink.runtime.operators -
-
Uses of TaskContext in org.apache.flink.runtime.iterative.task
Classes in org.apache.flink.runtime.iterative.task that implement TaskContext Modifier and Type Class Description classAbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT>The abstract base class for all tasks able to participate in an iteration.classIterationHeadTask<X,Y,S extends org.apache.flink.api.common.functions.Function,OT>The head is responsible for coordinating an iteration and can run aDriverinside.classIterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT>An intermediate iteration task, which runs aDriverinside.classIterationTailTask<S extends org.apache.flink.api.common.functions.Function,OT>An iteration tail, which runs a driver inside. -
Uses of TaskContext in org.apache.flink.runtime.operators
Classes in org.apache.flink.runtime.operators that implement TaskContext Modifier and Type Class Description classBatchTask<S extends org.apache.flink.api.common.functions.Function,OT>The base class for all batch tasks.Fields in org.apache.flink.runtime.operators declared as TaskContext Modifier and Type Field Description protected TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>AbstractOuterJoinDriver. taskContextprotected TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>JoinDriver. taskContextMethods in org.apache.flink.runtime.operators with parameters of type TaskContext Modifier and Type Method Description voidAbstractOuterJoinDriver. setup(TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> context)voidAllGroupCombineDriver. setup(TaskContext<org.apache.flink.api.common.functions.GroupCombineFunction<IN,OUT>,OUT> context)voidAllGroupReduceDriver. setup(TaskContext<org.apache.flink.api.common.functions.GroupReduceFunction<IT,OT>,OT> context)voidAllReduceDriver. setup(TaskContext<org.apache.flink.api.common.functions.ReduceFunction<T>,T> context)voidCoGroupDriver. setup(TaskContext<org.apache.flink.api.common.functions.CoGroupFunction<IT1,IT2,OT>,OT> context)voidCoGroupRawDriver. setup(TaskContext<org.apache.flink.api.common.functions.CoGroupFunction<IT1,IT2,OT>,OT> context)voidCoGroupWithSolutionSetFirstDriver. setup(TaskContext<org.apache.flink.api.common.functions.CoGroupFunction<IT1,IT2,OT>,OT> context)voidCoGroupWithSolutionSetSecondDriver. setup(TaskContext<org.apache.flink.api.common.functions.CoGroupFunction<IT1,IT2,OT>,OT> context)voidCrossDriver. setup(TaskContext<org.apache.flink.api.common.functions.CrossFunction<T1,T2,OT>,OT> context)voidDriver. setup(TaskContext<S,OT> context)voidFlatMapDriver. setup(TaskContext<org.apache.flink.api.common.functions.FlatMapFunction<IT,OT>,OT> context)voidGroupReduceCombineDriver. setup(TaskContext<org.apache.flink.api.common.functions.GroupCombineFunction<IN,OUT>,OUT> context)voidGroupReduceDriver. setup(TaskContext<org.apache.flink.api.common.functions.GroupReduceFunction<IT,OT>,OT> context)voidJoinDriver. setup(TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> context)voidJoinWithSolutionSetFirstDriver. setup(TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> context)voidJoinWithSolutionSetSecondDriver. setup(TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> context)voidMapDriver. setup(TaskContext<org.apache.flink.api.common.functions.MapFunction<IT,OT>,OT> context)voidMapPartitionDriver. setup(TaskContext<org.apache.flink.api.common.functions.MapPartitionFunction<IT,OT>,OT> context)voidNoOpDriver. setup(TaskContext<org.apache.flink.api.common.functions.AbstractRichFunction,T> context)voidReduceCombineDriver. setup(TaskContext<org.apache.flink.api.common.functions.ReduceFunction<T>,T> context)voidReduceDriver. setup(TaskContext<org.apache.flink.api.common.functions.ReduceFunction<T>,T> context)voidUnionWithTempOperator. setup(TaskContext<org.apache.flink.api.common.functions.Function,T> context)
-