public interface CatalystScan
PrunedFilteredScan
, this operator receives the raw expressions from the
org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
. Unlike the other APIs this
interface is NOT designed to be binary compatible across releases and thus should only be used
for experimentation.
Modifier and Type | Method and Description |
---|---|
RDD<Row> |
buildScan(scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> requiredColumns,
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Expression> filters) |