File tree Expand file tree Collapse file tree 1 file changed +7
-8
lines changed
sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/expressions/codegen Expand file tree Collapse file tree 1 file changed +7
-8
lines changed Original file line number Diff line number Diff line change @@ -37,14 +37,13 @@ abstract class CodeGenerator extends Logging {
3737
3838 val toolBox = runtimeMirror(getClass.getClassLoader).mkToolBox()
3939
40- // TODO: Use typetags?
41- val rowType = tq " org.apache.spark.sql.catalyst.expressions.Row "
42- val mutableRowType = tq " org.apache.spark.sql.catalyst.expressions.MutableRow "
43- val genericRowType = tq " org.apache.spark.sql.catalyst.expressions.GenericRow "
44- val genericMutableRowType = tq " org.apache.spark.sql.catalyst.expressions.GenericMutableRow "
45-
46- val projectionType = tq " org.apache.spark.sql.catalyst.expressions.Projection "
47- val mutableProjectionType = tq " org.apache.spark.sql.catalyst.expressions.MutableProjection "
40+ val rowType = typeOf[Row ]
41+ val mutableRowType = typeOf[MutableRow ]
42+ val genericRowType = typeOf[GenericRow ]
43+ val genericMutableRowType = typeOf[GenericMutableRow ]
44+
45+ val projectionType = typeOf[Projection ]
46+ val mutableProjectionType = typeOf[MutableProjection ]
4847
4948 private val curId = new java.util.concurrent.atomic.AtomicInteger ()
5049 private val javaSeperator = " $"
You can’t perform that action at this time.
0 commit comments