public class Sample extends SparkPlan implements scala.Product, scala.Serializable
Constructor and Description |
---|
Sample(double fraction,
boolean withReplacement,
long seed,
SparkPlan child) |
Modifier and Type | Method and Description |
---|---|
SparkPlan |
child() |
RDD<org.apache.spark.sql.catalyst.expressions.Row> |
execute()
Runs this query returning the result as an RDD.
|
double |
fraction() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> |
output() |
org.apache.spark.sql.catalyst.plans.physical.Partitioning |
outputPartitioning() |
long |
seed() |
boolean |
withReplacement() |
executeCollect, outputPartitioning, requiredChildDistribution
expressions, generateSchemaString, generateSchemaString, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionDown$1, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionUp$1, outputSet, printSchema, schemaString, transformAllExpressions, transformExpressions, transformExpressionsDown, transformExpressionsUp
apply, argString, asCode, children, collect, fastEquals, flatMap, foreach, generateTreeString, getNodeNumbered, id, makeCopy, map, mapChildren, nextId, nodeName, numberedTreeString, otherCopyArgs, sameInstance, simpleString, stringArgs, toString, transform, transformChildrenDown, transformChildrenUp, transformDown, transformUp, treeString, withNewChildren
public Sample(double fraction, boolean withReplacement, long seed, SparkPlan child)
public double fraction()
public boolean withReplacement()
public long seed()
public SparkPlan child()
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output()
output
in class org.apache.spark.sql.catalyst.plans.QueryPlan<SparkPlan>
public RDD<org.apache.spark.sql.catalyst.expressions.Row> execute()
SparkPlan
public org.apache.spark.sql.catalyst.plans.physical.Partitioning outputPartitioning()