org.apache.spark.sql.sources
Interface CatalystScan


public interface CatalystScan

::Experimental:: An interface for experimenting with a more direct connection to the query planner. Compared to PrunedFilteredScan, this operator receives the raw expressions from the LogicalPlan. Unlike the other APIs this interface is NOT designed to be binary compatible across releases and thus should only be used for experimentation.

Since:
1.3.0

Method Summary
 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)
           
 

Method Detail

buildScan

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)