Package

org.apache.spark.sql

internal

Permalink

package internal

All classes in this package are considered an internal API to Spark and are subject to change between minor releases.

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. class AQPQueryAnalyzer extends SnappyAnalyzer with AnalyzerInvocation

    Permalink
  2. trait AltName[T] extends AnyRef

    Permalink
  3. trait AnalyzerInvocation extends AnyRef

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

    Permalink
  5. class CatalogImpl extends Catalog

    Permalink

    Internal implementation of the user-facing Catalog.

  6. class CodeGenerationException extends Exception

    Permalink
  7. case class HiveSerDe(inputFormat: Option[String] = None, outputFormat: Option[String] = None, serde: Option[String] = None) extends Product with Serializable

    Permalink
  8. trait JoinQueryPlanning extends AnyRef

    Permalink
  9. 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.

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

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

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

    Permalink
  13. class SQLConf extends Serializable with internal.Logging

    Permalink

    A class that enables the setting and getting of mutable config parameters/hints.

    A class that enables the setting and getting of mutable config parameters/hints.

    In the presence of a SQLContext, these can be set and queried by passing SET commands into Spark SQL's query functions (i.e. sql()). Otherwise, users of this class can modify the hints by programmatically calling the setters and getters of this class.

    SQLConf is thread-safe (internally synchronized, so safe to be used in multiple threads).

  14. class SQLConfigEntry extends AnyRef

    Permalink
  15. final class SessionCatalogWrapper extends SnappySessionCatalog

    Permalink
  16. final class SnappyAQPSessionState extends SnappySessionState

    Permalink
  17. class SnappyConf extends SQLConf with Serializable

    Permalink
  18. class SnappySessionCatalog extends SessionCatalog

    Permalink

    ::DeveloperApi:: Catalog using Hive for persistence and adding Snappy extensions like stream/topK tables and returning LogicalPlan to materialize these entities.

    ::DeveloperApi:: Catalog using Hive for persistence and adding Snappy extensions like stream/topK tables and returning LogicalPlan to materialize these entities.

    Annotations
    @DeveloperApi()
  19. class VariableSubstitution extends AnyRef

    Permalink

    A helper class that enables substitution using syntax like ${var}, ${system:var} and ${env:var}.

    A helper class that enables substitution using syntax like ${var}, ${system:var} and ${env:var}.

    Variable substitution is controlled by SQLConf.variableSubstituteEnabled.

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 HiveSerDe extends Serializable

    Permalink
  4. 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.

  5. object SQLConf extends Serializable

    Permalink
  6. object SQLConfigEntry

    Permalink
  7. object SharedState

    Permalink
  8. object StaticSQLConf

    Permalink

    Static SQL configuration is a cross-session, immutable Spark configuration.

    Static SQL configuration is a cross-session, immutable Spark configuration. External users can see the static sql configs via SparkSession.conf, but can NOT set/unset them.

  9. object UDFFunction

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped