Package

org.apache.spark.sql

internal

Permalink

package internal

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. internal
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. trait AltName[T] extends AnyRef

    Permalink
  2. case class BypassRowLevelSecurity(child: Filter) extends UnaryNode with Product with Serializable

    Permalink
  3. class CodeGenerationException extends Exception

    Permalink
  4. class DefaultPlanner extends SparkPlanner with SnappyStrategies

    Permalink
  5. trait JoinQueryPlanning extends AnyRef

    Permalink
  6. class LogicalPlanWithHints extends BroadcastHint

    Permalink

    Wrap plan-specific query hints (like joinType).

    Wrap plan-specific query hints (like joinType). This extends Spark's BroadcastHint so that filters/projections etc can be pushed below this by optimizer.

  7. case class MarkerForCreateTableAsSelect(child: LogicalPlan) extends UnaryNode with Product with Serializable

    Permalink
  8. case class PutIntoColumnTable(table: LogicalPlan, insert: Insert, update: Update) extends BinaryNode with Product with Serializable

    Permalink
  9. trait SQLAltName[T] extends AltName[T]

    Permalink
  10. class SQLConfigEntry extends AnyRef

    Permalink
  11. class SnappyConf extends SQLConf with Serializable

    Permalink
  12. class SnappySessionState extends SessionState

    Permalink

Value Members

  1. object ColumnTableBulkOps

    Permalink

    Helper object for PutInto operations for column tables.

    Helper object for PutInto operations for column tables. This class takes the logical plans from SnappyParser and converts it into another plan.

  2. object ContextJarUtils extends Logging

    Permalink

    An utility class to store jar file reference with their individual class loaders.

    An utility class to store jar file reference with their individual class loaders. This is to reflect class changes at driver side. e.g. If an UDF definition changes the driver should pick up the correct UDF class. This class can not initialize itself after a driver failure. So the callers will have to make sure that the classloader gets initialized after a driver startup. Usually it can be achieved by adding classloader at query time.

  3. object LikeEscapeSimplification

    Permalink

    Deals with any escape characters in the LIKE pattern in optimization.

    Deals with any escape characters in the LIKE pattern in optimization. Does not deal with startsAndEndsWith equivalent of Spark's LikeSimplification so 'a%b' kind of pattern with additional escaped chars will not be optimized.

  4. object ResolveAggregationExpressions extends Rule[LogicalPlan]

    Permalink

    Rule to "normalize" ParamLiterals for the case of aggregation expression being used in projection.

    Rule to "normalize" ParamLiterals for the case of aggregation expression being used in projection. Specifically the ParamLiterals from aggregations need to be replaced into projection so that latter can be resolved successfully in plan execution because ParamLiterals will match expression only by position and not value at the time of execution. This rule is useful only before plan caching after parsing.

    See Spark's PhysicalAggregation rule for more details.

  5. object SQLConfigEntry

    Permalink
  6. object UDFFunction

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped