Type Members
-
-
-
case class
GroupingInfo(gEs: Seq[Expression], expandOpGExps: Seq[Expression], aEs: Seq[NamedExpression], expandOpProjection: Seq[Expression], aEExprIdToPos: Map[ExprId, Int], aEToLiteralExpr: Map[Expression, Expression] = ...) extends Product with Serializable
-
-
-
-
Value Members
-
final
def
!=(arg0: AnyRef): Boolean
-
final
def
!=(arg0: Any): Boolean
-
final
def
##(): Int
-
final
def
==(arg0: AnyRef): Boolean
-
final
def
==(arg0: Any): Boolean
-
-
-
-
-
def
addUnpushedAttributes(dqb: DruidQueryBuilder, e: Expression, isProjection: Boolean): Option[DruidQueryBuilder]
-
def
aggExpressions(aEs: Seq[Expression]): Seq[AggregateExpression]
-
def
aggregateExpression(dqb: DruidQueryBuilder, aggExp: AggregateExpression)(implicit expandOpProjection: Seq[Expression], aEExprIdToPos: Map[ExprId, Int], aEToLiteralExpr: Map[Expression, Expression]): Option[DruidQueryBuilder]
-
-
final
def
asInstanceOf[T0]: T0
-
-
def
canEvaluate(expr: Expression, plan: LogicalPlan): Boolean
-
def
clone(): AnyRef
-
def
debugTranslation(msg: ⇒ String): Unit
-
def
dimFilterExpression(dqb: DruidQueryBuilder, fe: Expression): Option[FilterSpec]
-
-
-
final
def
eq(arg0: AnyRef): Boolean
-
def
equals(arg0: Any): Boolean
-
def
exprIdToAttribute(e: Expression, plan: LogicalPlan): Option[(ExprId, Int)]
-
def
finalize(): Unit
-
def
findAttribute(e: Expression): Option[AttributeReference]
-
final
def
getClass(): Class[_]
-
-
def
hashCode(): Int
-
-
final
def
isInstanceOf[T0]: Boolean
-
def
isNumericType(dt: DataType): Boolean
-
def
isTraceEnabled(): Boolean
-
val
joinGraphTransform: ORTransform
-
-
-
-
def
log: Logger
-
def
logDebug(msg: ⇒ String, throwable: Throwable): Unit
-
def
logDebug(msg: ⇒ String): Unit
-
def
logError(msg: ⇒ String, throwable: Throwable): Unit
-
def
logError(msg: ⇒ String): Unit
-
def
logInfo(msg: ⇒ String, throwable: Throwable): Unit
-
def
logInfo(msg: ⇒ String): Unit
-
def
logName: String
-
def
logTrace(msg: ⇒ String, throwable: Throwable): Unit
-
def
logTrace(msg: ⇒ String): Unit
-
def
logWarning(msg: ⇒ String, throwable: Throwable): Unit
-
def
logWarning(msg: ⇒ String): Unit
-
final
def
ne(arg0: AnyRef): Boolean
-
final
def
notify(): Unit
-
final
def
notifyAll(): Unit
-
-
def
positionOfAttribute(e: Expression, plan: LogicalPlan): Option[(Expression, (AttributeReference, Int))]
-
def
projectExpression(dqb: DruidQueryBuilder, pe: Expression, joinAttrs: Set[String] = Set(), ignoreProjectList: Boolean = false): Option[DruidQueryBuilder]
-
def
replaceAlias(condition: Expression, aliases: AttributeMap[Expression]): Expression
-
def
splitConjunctivePredicates(condition: Expression): Seq[Expression]
-
def
splitDisjunctivePredicates(condition: Expression): Seq[Expression]
-
val
sqlContext: SQLContext
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
-
def
toString(): String
-
-
-
def
translateProjectFilter(dqb1: Option[DruidQueryBuilder], projectList: Seq[NamedExpression], filters: Seq[Expression], ignoreProjectList: Boolean = false, joinAttrs: Set[String] = Set()): Seq[DruidQueryBuilder]
-
def
unalias(e: Expression, agg: Aggregate): Option[Expression]
-
final
def
wait(): Unit
-
final
def
wait(arg0: Long, arg1: Int): Unit
-
final
def
wait(arg0: Long): Unit
Inherited from Logging
Inherited from PredicateHelper
Inherited from AnyRef
Inherited from Any