Package org.apache.flink.api.common.operators.base
-
Interface Summary Interface Description CrossOperatorBase.CrossWithLarge Marker interface to declare the second input as the larger one.CrossOperatorBase.CrossWithSmall Marker interface to declare the second input as the smaller one. -
Class Summary Class Description BulkIterationBase<T> BulkIterationBase.PartialSolutionPlaceHolder<OT> Specialized operator to use as a recognizable place-holder for the input to the step function when composing the nested data flow.BulkIterationBase.TerminationCriterionAggregationConvergence Convergence for the termination criterion is reached if no tuple is output at current iteration for the termination criterion branchBulkIterationBase.TerminationCriterionAggregator Aggregator that basically only adds 1 for every output tuple of the termination criterion branchBulkIterationBase.TerminationCriterionMapper<X> Special Mapper that is added before a termination criterion and is only a container for an special aggregatorCoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> CoGroupRawOperatorBase.SimpleListIterable<IN> CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> DeltaIterationBase<ST,WT> A DeltaIteration is similar to aBulkIterationBase
, but maintains state across the individual iteration steps.DeltaIterationBase.SolutionSetPlaceHolder<ST> Specialized operator to use as a recognizable place-holder for the solution set input to the step function.DeltaIterationBase.WorksetPlaceHolder<WT> Specialized operator to use as a recognizable place-holder for the working set input to the step function.FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> Base operator for the combineGroup transformation.GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> PartitionOperatorBase<IN> ReduceOperatorBase<T,FT extends ReduceFunction<T>> Base data flow operator for Reduce user-defined functions.SortPartitionOperatorBase<IN> -
Enum Summary Enum Description CrossOperatorBase.CrossHint The cross hint tells the system which sizes to expect from the data setsJoinOperatorBase.JoinHint An enumeration of hints, optionally usable to tell the system how exactly execute the join.OuterJoinOperatorBase.OuterJoinType PartitionOperatorBase.PartitionMethod ReduceOperatorBase.CombineHint An enumeration of hints, optionally usable to tell the system exactly how to execute the combiner phase of a reduce.