Modifier and Type | Method and Description |
---|---|
<K,V> DataSource<Tuple2<K,V>> |
ExecutionEnvironment.createHadoopInput(org.apache.hadoop.mapreduce.InputFormat<K,V> mapreduceInputFormat,
Class<K> key,
Class<V> value,
org.apache.hadoop.mapreduce.Job job)
Creates a
DataSet from the given InputFormat . |
<K,V> DataSource<Tuple2<K,V>> |
ExecutionEnvironment.createHadoopInput(org.apache.hadoop.mapred.InputFormat<K,V> mapredInputFormat,
Class<K> key,
Class<V> value,
org.apache.hadoop.mapred.JobConf job)
Creates a
DataSet from the given InputFormat . |
<K,V> DataSource<Tuple2<K,V>> |
ExecutionEnvironment.readHadoopFile(org.apache.hadoop.mapred.FileInputFormat<K,V> mapredInputFormat,
Class<K> key,
Class<V> value,
String inputPath)
Creates a
DataSet from the given FileInputFormat . |
<K,V> DataSource<Tuple2<K,V>> |
ExecutionEnvironment.readHadoopFile(org.apache.hadoop.mapreduce.lib.input.FileInputFormat<K,V> mapreduceInputFormat,
Class<K> key,
Class<V> value,
String inputPath)
Creates a
DataSet from the given FileInputFormat . |
<K,V> DataSource<Tuple2<K,V>> |
ExecutionEnvironment.readHadoopFile(org.apache.hadoop.mapreduce.lib.input.FileInputFormat<K,V> mapreduceInputFormat,
Class<K> key,
Class<V> value,
String inputPath,
org.apache.hadoop.mapreduce.Job job)
Creates a
DataSet from the given FileInputFormat . |
<K,V> DataSource<Tuple2<K,V>> |
ExecutionEnvironment.readHadoopFile(org.apache.hadoop.mapred.FileInputFormat<K,V> mapredInputFormat,
Class<K> key,
Class<V> value,
String inputPath,
org.apache.hadoop.mapred.JobConf job)
Creates a
DataSet from the given FileInputFormat . |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,V>> |
HadoopInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
void |
HadoopOutputFormat.writeRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,V>> |
HadoopInputFormat.getProducedType() |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,V> |
HadoopInputFormat.nextRecord(Tuple2<K,V> record) |
void |
HadoopOutputFormat.writeRecord(Tuple2<K,V> record) |
Modifier and Type | Method and Description |
---|---|
<T0,T1> DataSource<Tuple2<T0,T1>> |
CsvReader.types(Class<T0> type0,
Class<T1> type1)
Specifies the types for the CSV fields.
|
Modifier and Type | Method and Description |
---|---|
Tuple2<T1,T2> |
CrossOperator.DefaultCrossFunction.cross(T1 first,
T2 second) |
Modifier and Type | Method and Description |
---|---|
<T0,T1> ProjectOperator<T,Tuple2<T0,T1>> |
ProjectOperator.Projection.projectTuple2()
|
<T0,T1> JoinOperator.ProjectJoin<I1,I2,Tuple2<T0,T1>> |
JoinOperator.JoinProjection.projectTuple2()
Projects a pair of joined elements to a
Tuple with the previously selected fields. |
<T0,T1> CrossOperator.ProjectCross<I1,I2,Tuple2<T0,T1>> |
CrossOperator.CrossProjection.projectTuple2()
Projects a pair of crossed elements to a
Tuple with the previously selected fields. |
Modifier and Type | Method and Description |
---|---|
void |
JoinOperator.DefaultFlatJoinFunction.join(T1 first,
T2 second,
org.apache.flink.util.Collector<Tuple2<T1,T2>> out) |
Modifier and Type | Method and Description |
---|---|
Tuple2<K,T> |
KeyExtractingMapper.map(T value) |
Tuple2<K,T> |
PlanUnwrappingReduceOperator.ReduceWrapper.reduce(Tuple2<K,T> value1,
Tuple2<K,T> value2) |
Modifier and Type | Method and Description |
---|---|
void |
PlanRightUnwrappingJoinOperator.TupleRightUnwrappingJoiner.join(I1 value1,
Tuple2<K,I2> value2,
org.apache.flink.util.Collector<OUT> collector) |
void |
PlanLeftUnwrappingJoinOperator.TupleLeftUnwrappingJoiner.join(Tuple2<K,I1> value1,
I2 value2,
org.apache.flink.util.Collector<OUT> collector) |
void |
PlanBothUnwrappingJoinOperator.TupleUnwrappingJoiner.join(Tuple2<K,I1> value1,
Tuple2<K,I2> value2,
org.apache.flink.util.Collector<OUT> collector) |
void |
PlanBothUnwrappingJoinOperator.TupleUnwrappingJoiner.join(Tuple2<K,I1> value1,
Tuple2<K,I2> value2,
org.apache.flink.util.Collector<OUT> collector) |
T |
KeyRemovingMapper.map(Tuple2<K,T> value) |
Tuple2<K,T> |
PlanUnwrappingReduceOperator.ReduceWrapper.reduce(Tuple2<K,T> value1,
Tuple2<K,T> value2) |
Tuple2<K,T> |
PlanUnwrappingReduceOperator.ReduceWrapper.reduce(Tuple2<K,T> value1,
Tuple2<K,T> value2) |
Modifier and Type | Method and Description |
---|---|
void |
PlanRightUnwrappingCoGroupOperator.TupleRightUnwrappingCoGrouper.coGroup(Iterable<I1> records1,
Iterable<Tuple2<K,I2>> records2,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanLeftUnwrappingCoGroupOperator.TupleLeftUnwrappingCoGrouper.coGroup(Iterable<Tuple2<K,I1>> records1,
Iterable<I2> records2,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanBothUnwrappingCoGroupOperator.TupleBothUnwrappingCoGrouper.coGroup(Iterable<Tuple2<K,I1>> records1,
Iterable<Tuple2<K,I2>> records2,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanBothUnwrappingCoGroupOperator.TupleBothUnwrappingCoGrouper.coGroup(Iterable<Tuple2<K,I1>> records1,
Iterable<Tuple2<K,I2>> records2,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanUnwrappingGroupCombineOperator.TupleUnwrappingGroupCombiner.combine(Iterable<Tuple2<K,IN>> values,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer.combine(Iterable<Tuple2<K,IN>> values,
org.apache.flink.util.Collector<Tuple2<K,IN>> out) |
void |
PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer.combine(Iterable<Tuple2<K,IN>> values,
org.apache.flink.util.Collector<Tuple2<K,IN>> out) |
void |
PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer.reduce(Iterable<Tuple2<K,IN>> values,
org.apache.flink.util.Collector<OUT> out) |
void |
PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer.reduce(Iterable<Tuple2<K,IN>> values,
org.apache.flink.util.Collector<OUT> out) |
void |
TupleWrappingCollector.set(org.apache.flink.util.Collector<Tuple2<K,IN>> wrappedCollector) |
void |
TupleUnwrappingIterator.set(Iterator<Tuple2<K,T>> iterator) |
Constructor and Description |
---|
PlanBothUnwrappingCoGroupOperator(org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> type,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
PlanBothUnwrappingCoGroupOperator(org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> type,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
PlanBothUnwrappingJoinOperator(org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
PlanBothUnwrappingJoinOperator(org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
PlanLeftUnwrappingCoGroupOperator(org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
int[] key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
org.apache.flink.api.common.typeinfo.TypeInformation<I2> typeInfo2) |
PlanLeftUnwrappingJoinOperator(org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
int[] key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
org.apache.flink.api.common.typeinfo.TypeInformation<I2> typeInfo2) |
PlanRightUnwrappingCoGroupOperator(org.apache.flink.api.common.functions.CoGroupFunction<I1,I2,OUT> udf,
int[] key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> resultType,
org.apache.flink.api.common.typeinfo.TypeInformation<I1> typeInfo1,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
PlanRightUnwrappingJoinOperator(org.apache.flink.api.common.functions.FlatJoinFunction<I1,I2,OUT> udf,
int[] key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> type,
org.apache.flink.api.common.typeinfo.TypeInformation<I1> typeInfo1,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
PlanUnwrappingGroupCombineOperator(org.apache.flink.api.common.functions.GroupCombineFunction<IN,OUT> udf,
Keys.SelectorFunctionKeys<IN,K> key,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,IN>> typeInfoWithKey) |
PlanUnwrappingReduceGroupOperator(org.apache.flink.api.common.functions.GroupReduceFunction<IN,OUT> udf,
Keys.SelectorFunctionKeys<IN,K> key,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> outType,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,IN>> typeInfoWithKey,
boolean combinable) |
PlanUnwrappingReduceOperator(org.apache.flink.api.common.functions.ReduceFunction<T> udf,
Keys.SelectorFunctionKeys<T,K> key,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<T> type,
org.apache.flink.api.common.typeinfo.TypeInformation<Tuple2<K,T>> typeInfoWithKey) |
Modifier and Type | Method and Description |
---|---|
Tuple2<T0,T1> |
Tuple2.copy()
Shallow tuple copy.
|
Tuple2<T1,T0> |
Tuple2.swap()
Returns a shallow copy of the tuple with swapped values.
|
Modifier and Type | Method and Description |
---|---|
Tuple2<T0,T1>[] |
Tuple2Builder.build() |
Copyright © 2014–2015 The Apache Software Foundation. All rights reserved.