Skip to content
Closed
Show file tree
Hide file tree
Changes from 1 commit
Commits
Show all changes
26 commits
Select commit Hold shift + click to select a range
aa7120e
Initial Broadcast design
hvanhovell Feb 4, 2016
c2b7533
Fix Exchange and initial code gen attempt.
hvanhovell Feb 4, 2016
6a5568a
Move broadcast retreval to SparkPlan
hvanhovell Feb 6, 2016
9adecdd
Merge remote-tracking branch 'spark/master' into SPARK-13136
hvanhovell Feb 6, 2016
d0194fb
Fix Codegen & Add other broadcast joins.
hvanhovell Feb 6, 2016
02a61b8
Minor touchup
hvanhovell Feb 6, 2016
c12c8e6
Move broadcast relation retrieval.
hvanhovell Feb 7, 2016
c7dd7ae
Remove codegen from broadcast.
hvanhovell Feb 8, 2016
e847383
Merge remote-tracking branch 'spark/master' into SPARK-13136
hvanhovell Feb 10, 2016
d73f11c
Merge remote-tracking branch 'apache-github/master' into SPARK-13136
hvanhovell Feb 12, 2016
9c0f4bf
Remove closure passing.
hvanhovell Feb 14, 2016
da4a966
Merge remote-tracking branch 'apache-github/master' into SPARK-13136
hvanhovell Feb 14, 2016
681f347
Move transform into BroadcastMode
hvanhovell Feb 15, 2016
7db240a
Clean-up
hvanhovell Feb 15, 2016
3ad839d
Code Review.
hvanhovell Feb 16, 2016
1116768
No newline at EOF :(
hvanhovell Feb 16, 2016
a5501cf
Rename exchanges and merge Broadcast.scala into exchange.scala.
hvanhovell Feb 17, 2016
c7429bb
Merge remote-tracking branch 'apache-github/master' into SPARK-13136
hvanhovell Feb 17, 2016
b12bbc2
Merge remote-tracking branch 'apache-github/master' into SPARK-13136
hvanhovell Feb 20, 2016
9d52650
Revert renaming of variabels in LeftSemiJoinBNL.
hvanhovell Feb 20, 2016
54b558d
Revert renaming of variabels in LeftSemiJoinBNL.
hvanhovell Feb 20, 2016
f33d2cb
Move all exchange related operators into the exchange package.
hvanhovell Feb 21, 2016
28363c8
CR
hvanhovell Feb 21, 2016
f812a31
Merge remote-tracking branch 'apache-github/master' into SPARK-13136
hvanhovell Feb 21, 2016
4b5978b
put broadcast mode in a separate file.
hvanhovell Feb 21, 2016
c8c175e
Fix style in sqlcontext.
hvanhovell Feb 21, 2016
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
Prev Previous commit
Next Next commit
Clean-up
  • Loading branch information
hvanhovell committed Feb 15, 2016
commit 7db240a93ea4fce858c36c80c7d5c82784190dbc
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,6 @@ import org.apache.spark.sql.catalyst.errors.attachTree
import org.apache.spark.sql.catalyst.expressions._
import org.apache.spark.sql.catalyst.plans.physical._
import org.apache.spark.sql.catalyst.rules.Rule
import org.apache.spark.sql.execution.joins.{HashedRelation, HashedRelationBroadcastMode, HashSemiJoin, HashSetBroadcastMode}
import org.apache.spark.util.MutablePair

/**
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -49,6 +49,7 @@ case class EvaluatePython(
override def references: AttributeSet = udf.references
}


object EvaluatePython {
def apply(udf: PythonUDF, child: LogicalPlan): EvaluatePython =
new EvaluatePython(udf, child, AttributeReference("pythonUDF", udf.dataType)())
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -22,7 +22,8 @@ import scala.reflect.ClassTag
import org.scalatest.BeforeAndAfterAll

import org.apache.spark.{AccumulatorSuite, SparkConf, SparkContext}
import org.apache.spark.sql.{QueryTest, SQLConf, SQLContext}
import org.apache.spark.sql.{QueryTest, SQLContext}
import org.apache.spark.sql.execution.EnsureRequirements
import org.apache.spark.sql.functions._

/**
Expand All @@ -43,7 +44,6 @@ class BroadcastJoinSuite extends QueryTest with BeforeAndAfterAll {
val conf = new SparkConf()
.setMaster("local-cluster[2,1,1024]")
.setAppName("testing")
.set("spark.sql.codegen.wholeStage", "false")
val sc = new SparkContext(conf)
sqlContext = new SQLContext(sc)
}
Expand All @@ -63,7 +63,7 @@ class BroadcastJoinSuite extends QueryTest with BeforeAndAfterAll {
// Comparison at the end is for broadcast left semi join
val joinExpression = df1("key") === df2("key") && df1("value") > df2("value")
val df3 = df1.join(broadcast(df2), joinExpression, joinType)
val plan = df3.queryExecution.executedPlan
val plan = EnsureRequirements(sqlContext).apply(df3.queryExecution.sparkPlan)
assert(plan.collect { case p: T => p }.size === 1)
plan.executeCollect()
}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -29,10 +29,6 @@ import org.apache.spark.sql.types.{IntegerType, StringType, StructType}
class InnerJoinSuite extends SparkPlanTest with SharedSQLContext {
import testImplicits.localSeqToDataFrameHolder

override def beforeAll(): Unit = {
super.beforeAll()
}

private lazy val myUpperCaseData = sqlContext.createDataFrame(
sparkContext.parallelize(Seq(
Row(1, "A"),
Expand Down