Skip to content

Commit

Permalink
[HOTFIX] Fix ORC build break
Browse files Browse the repository at this point in the history
Fix break caused by merging #6225 and #6194.

Author: Michael Armbrust <[email protected]>

Closes #6244 from marmbrus/fixOrcBuildBreak and squashes the following commits:

b10e47b [Michael Armbrust] [HOTFIX] Fix ORC Build break

(cherry picked from commit fcf90b7)
Signed-off-by: Andrew Or <[email protected]>
  • Loading branch information
marmbrus authored and Andrew Or committed May 18, 2015
1 parent 39add3d commit ba502ab
Showing 1 changed file with 6 additions and 5 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,7 @@ package org.apache.spark.sql.hive.orc
import java.util.{Objects, Properties}

import org.apache.hadoop.conf.Configuration
import org.apache.hadoop.fs.Path
import org.apache.hadoop.fs.{FileStatus, Path}
import org.apache.hadoop.hive.conf.HiveConf.ConfVars
import org.apache.hadoop.hive.ql.io.orc.{OrcInputFormat, OrcOutputFormat, OrcSerde, OrcSplit}
import org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector
Expand Down Expand Up @@ -171,9 +171,10 @@ private[sql] case class OrcRelation(
maybePartitionSpec)
}

override def buildScan(requiredColumns: Array[String],
override def buildScan(
requiredColumns: Array[String],
filters: Array[Filter],
inputPaths: Array[String]): RDD[Row] = {
inputPaths: Array[FileStatus]): RDD[Row] = {
val output = StructType(requiredColumns.map(dataSchema(_))).toAttributes
OrcTableScan(output, this, filters, inputPaths).execute()
}
Expand All @@ -194,7 +195,7 @@ private[orc] case class OrcTableScan(
attributes: Seq[Attribute],
@transient relation: OrcRelation,
filters: Array[Filter],
inputPaths: Array[String])
inputPaths: Array[FileStatus])
extends Logging
with HiveInspectors {

Expand Down Expand Up @@ -256,7 +257,7 @@ private[orc] case class OrcTableScan(
addColumnIds(attributes, relation, conf)

if (inputPaths.nonEmpty) {
FileInputFormat.setInputPaths(job, inputPaths.map(new Path(_)): _*)
FileInputFormat.setInputPaths(job, inputPaths.map(_.getPath): _*)
}

val inputFormatClass =
Expand Down

0 comments on commit ba502ab

Please sign in to comment.