public interface TableReader
Modifier and Type | Method and Description |
---|---|
RDD<org.apache.spark.sql.catalyst.InternalRow> |
makeRDDForPartitionedTable(scala.collection.Seq<org.apache.hadoop.hive.ql.metadata.Partition> partitions) |
RDD<org.apache.spark.sql.catalyst.InternalRow> |
makeRDDForTable(org.apache.hadoop.hive.ql.metadata.Table hiveTable) |
RDD<org.apache.spark.sql.catalyst.InternalRow> makeRDDForPartitionedTable(scala.collection.Seq<org.apache.hadoop.hive.ql.metadata.Partition> partitions)
RDD<org.apache.spark.sql.catalyst.InternalRow> makeRDDForTable(org.apache.hadoop.hive.ql.metadata.Table hiveTable)