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

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

Introduction

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

Usage

From source file com.ibm.bi.dml.runtime.instructions.spark.functions.ExtractGroupNWeights.java

public class ExtractGroupNWeights implements
        PairFlatMapFunction<Tuple2<MatrixIndexes, Tuple2<Iterable<Tuple2<MatrixBlock, MatrixBlock>>, Iterable<MatrixBlock>>>, Long, WeightedCell> {

    private static final long serialVersionUID = -188180042997588072L;

    @Override

From source file com.ibm.bi.dml.runtime.instructions.spark.functions.MatrixVectorBinaryOpPartitionFunction.java

public class MatrixVectorBinaryOpPartitionFunction
        implements PairFlatMapFunction<Iterator<Tuple2<MatrixIndexes, MatrixBlock>>, MatrixIndexes, MatrixBlock> {
    private static final long serialVersionUID = 9096091404578628534L;

    private BinaryOperator _op = null;
    private PartitionedBroadcastMatrix _pmV = null;

From source file com.ibm.bi.dml.runtime.instructions.spark.functions.OuterVectorBinaryOpFunction.java

public class OuterVectorBinaryOpFunction
        implements PairFlatMapFunction<Tuple2<MatrixIndexes, MatrixBlock>, MatrixIndexes, MatrixBlock> {
    private static final long serialVersionUID = 1730704346934726826L;

    private BinaryOperator _op;
    private PartitionedBroadcastMatrix _pmV;

From source file com.ibm.bi.dml.runtime.instructions.spark.functions.ReplicateVectorFunction.java

public class ReplicateVectorFunction
        implements PairFlatMapFunction<Tuple2<MatrixIndexes, MatrixBlock>, MatrixIndexes, MatrixBlock> {

    private static final long serialVersionUID = -1505557561471236851L;

    private boolean _byRow;

From source file com.lambda.stack.HashTagMapper.java

/**
 *
 * @author uriel
 */
public class HashTagMapper implements PairFlatMapFunction<Status, String, Integer> {

From source file com.lambda.stack.HashTagUsageMapper.java

/**
 *
 * @author Dariusz Hudziak
 */
public class HashTagUsageMapper implements
        PairFlatMapFunction<Tuple3<Status, Integer, Integer>, Tuple3<Integer, Integer, Integer>, Integer> {

From source file com.lambda.stack.UserMapper.java

/**
 *
 * @author uriel
 */
public class UserMapper implements PairFlatMapFunction<Status, String, Integer> {
    @Override

From source file com.lambda.stack.UserUsageMapper.java

/**
 *
 * @author uriel
 */
public class UserUsageMapper implements
        PairFlatMapFunction<Tuple3<Status, Integer, Integer>, Tuple3<Integer, Integer, Integer>, Integer> {

From source file com.splicemachine.derby.stream.spark.ExceptionWrapperFunction.java

/**
 * This function wraps any Exception caused by the read stack in Spark in a Tuple2, for consumption by the
 * RecordWriter implementation.
 */
public class ExceptionWrapperFunction<K, V>
        implements PairFlatMapFunction<Iterator<Tuple2<K, V>>, K, Either<Exception, V>>, Serializable {

From source file com.stratio.decision.functions.PairDataFunction.java

public class PairDataFunction
        implements PairFlatMapFunction<Iterator<StratioStreamingMessage>, StreamAction, StratioStreamingMessage> {

    private static final long serialVersionUID = -1456940258968414737L;

    @Override