Example usage for org.apache.spark.api.java.function PairFlatMapFunction subclass-usage

List of usage examples for org.apache.spark.api.java.function PairFlatMapFunction subclass-usage

Introduction

In this page you can find the example usage for org.apache.spark.api.java.function PairFlatMapFunction subclass-usage.

Usage

From source file org.apache.crunch.impl.spark.fn.CombineMapsideFunction.java

public class CombineMapsideFunction<K, V> extends PairFlatMapFunction<Iterator<Tuple2<K, V>>, K, V> {

    private static final int REDUCE_EVERY_N = 50000;

    private final CombineFn<K, V> combineFn;
    private final SparkRuntimeContext ctxt;

From source file org.apache.crunch.impl.spark.fn.PairFlatMapDoFn.java

public class PairFlatMapDoFn<T, K, V> extends PairFlatMapFunction<Iterator<T>, K, V> {
    private final DoFn<T, Pair<K, V>> fn;
    private final SparkRuntimeContext ctxt;

    public PairFlatMapDoFn(DoFn<T, Pair<K, V>> fn, SparkRuntimeContext ctxt) {
        this.fn = fn;

From source file org.apache.crunch.impl.spark.fn.PairFlatMapPairDoFn.java

public class PairFlatMapPairDoFn<K, V, K2, V2> extends PairFlatMapFunction<Iterator<Tuple2<K, V>>, K2, V2> {
    private final DoFn<Pair<K, V>, Pair<K2, V2>> fn;
    private final SparkRuntimeContext ctxt;

    public PairFlatMapPairDoFn(DoFn<Pair<K, V>, Pair<K2, V2>> fn, SparkRuntimeContext ctxt) {
        this.fn = fn;

From source file org.apache.crunch.impl.spark.fn.ReduceGroupingFunction.java

public class ReduceGroupingFunction
        extends PairFlatMapFunction<Iterator<Tuple2<ByteArray, List<byte[]>>>, ByteArray, List<byte[]>> {

    private final GroupingOptions options;
    private final PGroupedTableType ptype;
    private final SparkRuntimeContext ctxt;