Modifier and Type | Method and Description |
---|---|
<T0,T1,T2> DataSource<Tuple3<T0,T1,T2>> |
CsvReader.types(Class<T0> type0,
Class<T1> type1,
Class<T2> type2)
Specifies the types for the CSV fields.
|
Modifier and Type | Method and Description |
---|---|
<T0,T1,T2> ProjectOperator<T,Tuple3<T0,T1,T2>> |
ProjectOperator.Projection.projectTuple3()
|
<T0,T1,T2> JoinOperator.ProjectJoin<I1,I2,Tuple3<T0,T1,T2>> |
JoinOperator.JoinProjection.projectTuple3()
Projects a pair of joined elements to a
Tuple with the previously selected fields. |
<T0,T1,T2> CrossOperator.ProjectCross<I1,I2,Tuple3<T0,T1,T2>> |
CrossOperator.CrossProjection.projectTuple3()
Projects a pair of crossed elements to a
Tuple with the previously selected fields. |
Modifier and Type | Method and Description |
---|---|
Tuple3<K1,K2,T> |
TwoKeyExtractingMapper.map(T value) |
Modifier and Type | Method and Description |
---|---|
void |
PlanUnwrappingSortedGroupCombineOperator.TupleUnwrappingGroupReducer.combine(Iterable<Tuple3<K1,K2,IN>> values,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer.combine(Iterable<Tuple3<K1,K2,IN>> values,
org.apache.flink.util.Collector<Tuple3<K1,K2,IN>> out) |
void |
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer.combine(Iterable<Tuple3<K1,K2,IN>> values,
org.apache.flink.util.Collector<Tuple3<K1,K2,IN>> out) |
void |
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer.reduce(Iterable<Tuple3<K1,K2,IN>> values,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer.reduce(Iterable<Tuple3<K1,K2,IN>> values,
org.apache.flink.util.Collector<OUT> out) |
void |
Tuple3WrappingCollector.set(org.apache.flink.util.Collector<Tuple3<K1,K2,IN>> wrappedCollector) |
void |
Tuple3UnwrappingIterator.set(Iterator<Tuple3<K1,K2,T>> iterator) |
Constructor and Description |
---|
PlanUnwrappingSortedGroupCombineOperator(org.apache.flink.api.common.functions.GroupCombineFunction<IN,OUT> udf,
Keys.SelectorFunctionKeys<IN,K1> groupingKey,
Keys.SelectorFunctionKeys<IN,K2> sortingKey,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple3<K1,K2,IN>> typeInfoWithKey) |
PlanUnwrappingSortedReduceGroupOperator(org.apache.flink.api.common.functions.GroupReduceFunction<IN,OUT> udf,
Keys.SelectorFunctionKeys<IN,K1> groupingKey,
Keys.SelectorFunctionKeys<IN,K2> sortingKey,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple3<K1,K2,IN>> typeInfoWithKey,
boolean combinable) |
Modifier and Type | Method and Description |
---|---|
Tuple3<T0,T1,T2> |
Tuple3.copy()
Shallow tuple copy.
|
Modifier and Type | Method and Description |
---|---|
Tuple3<T0,T1,T2>[] |
Tuple3Builder.build() |
Copyright © 2014–2015 The Apache Software Foundation. All rights reserved.