public static class HiveStrategies.HiveCommandStrategy
extends org.apache.spark.sql.catalyst.planning.GenericStrategy<org.apache.spark.sql.execution.SparkPlan>
implements scala.Product, scala.Serializable
Constructor and Description |
---|
HiveStrategies.HiveCommandStrategy(HiveContext context) |
Modifier and Type | Method and Description |
---|---|
scala.collection.Seq<org.apache.spark.sql.execution.SparkPlan> |
apply(org.apache.spark.sql.catalyst.plans.logical.LogicalPlan plan) |
HiveContext |
context() |
isTraceEnabled, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning, org$apache$spark$Logging$$log__$eq, org$apache$spark$Logging$$log_
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
productArity, productElement, productIterator, productPrefix
initializeIfNecessary, initializeLogging, log_
public HiveStrategies.HiveCommandStrategy(HiveContext context)
public HiveContext context()
public scala.collection.Seq<org.apache.spark.sql.execution.SparkPlan> apply(org.apache.spark.sql.catalyst.plans.logical.LogicalPlan plan)
apply
in class org.apache.spark.sql.catalyst.planning.GenericStrategy<org.apache.spark.sql.execution.SparkPlan>