org.apache.spark.api.r
Class PairwiseRRDD<T>

Object
  extended by org.apache.spark.rdd.RDD<U>
      extended by org.apache.spark.api.r.BaseRRDD<T,scala.Tuple2<Object,byte[]>>
          extended by org.apache.spark.api.r.PairwiseRRDD<T>
All Implemented Interfaces:
java.io.Serializable, Logging

public class PairwiseRRDD<T>
extends BaseRRDD<T,scala.Tuple2<Object,byte[]>>

Form an RDD[(Int, Array[Byte])] from key-value pairs returned from R. This is used by SparkR's shuffle operations.

See Also:
Serialized Form

Constructor Summary
PairwiseRRDD(RDD<T> parent, int numPartitions, byte[] hashFunc, String deserializer, byte[] packageNames, String rLibDir, Object[] broadcastVars, scala.reflect.ClassTag<T> evidence$3)
           
 
Method Summary
 JavaPairRDD<Object,byte[]> asJavaPairRDD()
           
 
Methods inherited from class org.apache.spark.api.r.BaseRRDD
compute, getPartitions
 
Methods inherited from class org.apache.spark.rdd.RDD
aggregate, cache, cartesian, checkpoint, checkpointData, coalesce, collect, collect, context, count, countApprox, countApproxDistinct, countApproxDistinct, countByValue, countByValueApprox, creationSite, dependencies, distinct, distinct, doubleRDDToDoubleRDDFunctions, filter, filterWith, first, flatMap, flatMapWith, fold, foreach, foreachPartition, foreachWith, getCheckpointFile, getStorageLevel, glom, groupBy, groupBy, groupBy, id, intersection, intersection, intersection, isCheckpointed, isEmpty, iterator, keyBy, map, mapPartitions, mapPartitionsWithContext, mapPartitionsWithIndex, mapPartitionsWithSplit, mapWith, max, min, name, numericRDDToDoubleRDDFunctions, partitioner, partitions, persist, persist, pipe, pipe, pipe, preferredLocations, randomSplit, rddToAsyncRDDActions, rddToOrderedRDDFunctions, rddToPairRDDFunctions, rddToSequenceFileRDDFunctions, reduce, repartition, sample, saveAsObjectFile, saveAsTextFile, saveAsTextFile, scope, setName, sortBy, sparkContext, subtract, subtract, subtract, take, takeOrdered, takeSample, toArray, toDebugString, toJavaRDD, toLocalIterator, top, toString, treeAggregate, treeReduce, union, unpersist, zip, zipPartitions, zipPartitions, zipPartitions, zipPartitions, zipPartitions, zipPartitions, zipWithIndex, zipWithUniqueId
 
Methods inherited from class Object
equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
 
Methods inherited from interface org.apache.spark.Logging
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
 

Constructor Detail

PairwiseRRDD

public PairwiseRRDD(RDD<T> parent,
                    int numPartitions,
                    byte[] hashFunc,
                    String deserializer,
                    byte[] packageNames,
                    String rLibDir,
                    Object[] broadcastVars,
                    scala.reflect.ClassTag<T> evidence$3)
Method Detail

asJavaPairRDD

public JavaPairRDD<Object,byte[]> asJavaPairRDD()