Class

org.apache.spark.sql.internal

SnappySessionCatalog

Related Doc: package internal

Permalink

class SnappySessionCatalog extends SessionCatalog

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

Annotations
@DeveloperApi()
Linear Supertypes
SessionCatalog, internal.Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SnappySessionCatalog
  2. SessionCatalog
  3. Logging
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SnappySessionCatalog(externalCatalog: SnappyExternalCatalog, snappySession: SnappySession, globalTempViewManager: GlobalTempViewManager, functionResourceLoader: FunctionResourceLoader, functionRegistry: FunctionRegistry, sqlConf: SQLConf, hadoopConf: Configuration)

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. def addMissingGlobalTempSchema(name: TableIdentifier): TableIdentifier

    Permalink

    SnappyData allows the schema for global temporary views to be optional so this method adds it to TableIdentifier if required so that super methods can be invoked directly.

    SnappyData allows the schema for global temporary views to be optional so this method adds it to TableIdentifier if required so that super methods can be invoked directly.

    Attributes
    protected
  5. def alterDatabase(dbDefinition: CatalogDatabase): Unit

    Permalink
    Definition Classes
    SessionCatalog
  6. def alterPartitions(tableName: TableIdentifier, parts: Seq[CatalogTablePartition]): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  7. def alterTable(table: CatalogTable): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  8. def alterTempViewDefinition(name: TableIdentifier, viewDefinition: LogicalPlan): Boolean

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  9. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  10. final def caseSensitiveAnalysis: Boolean

    Permalink
  11. def clearTempTables(): Unit

    Permalink
    Definition Classes
    SessionCatalog
  12. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  13. def compatibleSchema(schema1: StructType, schema2: StructType): Boolean

    Permalink
  14. var convertCharTypesInMetadata: Boolean

    Permalink

    Can be used to temporarily switch the metadata returned by catalog to use CharType and VarcharTypes.

    Can be used to temporarily switch the metadata returned by catalog to use CharType and VarcharTypes. Is to be used for only temporary change by a caller that wishes the consume the result because rest of Spark cannot deal with those types.

    Attributes
    protected[org.apache.spark.sql]
  15. def createDatabase(schemaDefinition: CatalogDatabase, ignoreIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  16. def createFunction(funcDefinition: CatalogFunction, ignoreIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  17. def createGlobalTempView(name: String, viewDefinition: LogicalPlan, overrideIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SessionCatalog
  18. def createPartitions(tableName: TableIdentifier, parts: Seq[CatalogTablePartition], ignoreIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  19. def createPolicy(policyIdent: TableIdentifier, targetTable: TableIdentifier, policyFor: String, policyApplyTo: Seq[String], expandedPolicyApplyTo: Seq[String], currentUser: String, filterString: String): Unit

    Permalink
  20. def createTable(table: CatalogTable, ignoreIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  21. def createTempFunction(name: String, info: ExpressionInfo, funcDefinition: FunctionBuilder, ignoreIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SessionCatalog
  22. def createTempView(name: String, tableDefinition: LogicalPlan, overrideIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SessionCatalog
  23. var currentDb: String

    Permalink
    Attributes
    protected
    Definition Classes
    SessionCatalog
  24. def databaseExists(db: String): Boolean

    Permalink
    Definition Classes
    SessionCatalog
  25. val defaultSchemaName: String

    Permalink
  26. def defaultTablePath(tableIdent: TableIdentifier): String

    Permalink
    Definition Classes
    SessionCatalog
  27. def destroyAndRegisterBuiltInFunctionsForTests(): Unit

    Permalink

    Test only method

  28. def dropAllSchemaObjects(schemaName: String, ignoreIfNotExists: Boolean, cascade: Boolean): Unit

    Permalink

    Drop all the objects in a schema.

    Drop all the objects in a schema. The provided schema must already be formatted with a call to formatDatabaseName.

  29. def dropDatabase(schema: String, ignoreIfNotExists: Boolean, cascade: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  30. def dropFromTemporaryBaseTable(table: CatalogTable): Unit

    Permalink
    Attributes
    protected
  31. def dropFunction(name: FunctionIdentifier, ignoreIfNotExists: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  32. def dropGlobalTempView(name: String): Boolean

    Permalink
    Definition Classes
    SessionCatalog
  33. def dropPartitions(tableName: TableIdentifier, specs: Seq[TablePartitionSpec], ignoreIfNotExists: Boolean, purge: Boolean, retainData: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  34. def dropTable(tableIdent: TableIdentifier, ignoreIfNotExists: Boolean, purge: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  35. def dropTempFunction(name: String, ignoreIfNotExists: Boolean): Unit

    Permalink
    Definition Classes
    SessionCatalog
  36. def dropTempView(name: String): Boolean

    Permalink
    Definition Classes
    SessionCatalog
  37. def dropTemporaryTable(tableIdent: TableIdentifier): Unit

    Permalink
    Attributes
    protected
  38. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  39. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  40. val externalCatalog: SnappyExternalCatalog

    Permalink
  41. def failFunctionLookup(name: String): Nothing

    Permalink
    Attributes
    protected
    Definition Classes
    SessionCatalog
  42. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  43. def formatDatabaseName(name: String): String

    Permalink

    Format schema name.

    Format schema name. Hive meta-store is case-insensitive so always convert to upper case.

    Definition Classes
    SnappySessionCatalog → SessionCatalog
  44. def formatName(name: String): String

    Permalink
  45. def formatTableName(name: String): String

    Permalink

    Format table name.

    Format table name. Hive meta-store is case-insensitive so always convert to upper case.

    Definition Classes
    SnappySessionCatalog → SessionCatalog
  46. def functionExists(name: FunctionIdentifier): Boolean

    Permalink
    Definition Classes
    SessionCatalog
  47. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  48. final def getCombinedPolicyFilterForExternalTable(rlsRelation: RowLevelSecurityRelation, wrappingLogicalRelation: Option[LogicalRelation], currentUser: Option[String]): Option[Filter]

    Permalink
  49. final def getCombinedPolicyFilterForNativeTable(rlsRelation: RowLevelSecurityRelation, wrappingLogicalRelation: Option[LogicalRelation]): Option[Filter]

    Permalink
  50. def getCurrentDatabase: String

    Permalink
    Definition Classes
    SessionCatalog
  51. final def getCurrentSchema: String

    Permalink
  52. def getDataSourceRelations[T](tableType: Type): Seq[T]

    Permalink
  53. def getDatabaseMetadata(db: String): CatalogDatabase

    Permalink
    Definition Classes
    SessionCatalog
  54. def getDefaultDBPath(db: String): String

    Permalink
    Definition Classes
    SessionCatalog
  55. def getFunctionMetadata(name: FunctionIdentifier): CatalogFunction

    Permalink
    Definition Classes
    SessionCatalog
  56. def getGlobalTempView(name: String): Option[LogicalPlan]

    Permalink
    Definition Classes
    SessionCatalog
  57. def getKeyColumns(table: String): Seq[catalog.Column]

    Permalink

    API to get primary key or Key Columns of a SnappyData table

  58. def getKeyColumnsAndPositions(table: String): Seq[(catalog.Column, Int)]

    Permalink

    API to get primary key or Key Columns of a SnappyData table

  59. def getPartition(tableName: TableIdentifier, spec: TablePartitionSpec): CatalogTablePartition

    Permalink
    Definition Classes
    SessionCatalog
  60. final def getSchemaName(identifier: IdentifierWithDatabase): String

    Permalink
  61. def getTableMetadata(name: TableIdentifier): CatalogTable

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  62. def getTableMetadataOption(name: TableIdentifier): Option[CatalogTable]

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  63. def getTempView(name: String): Option[LogicalPlan]

    Permalink
    Definition Classes
    SessionCatalog
  64. def getTempViewOrPermanentTableMetadata(name: TableIdentifier): CatalogTable

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  65. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  66. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  67. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  68. def isLocalTemporaryView(name: TableIdentifier): Boolean

    Permalink
  69. def isTemporaryFunction(name: FunctionIdentifier): Boolean

    Permalink
    Definition Classes
    SessionCatalog
  70. def isTemporaryTable(name: TableIdentifier): Boolean

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  71. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  72. def listDatabases(): Seq[String]

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  73. def listDatabases(pattern: String): Seq[String]

    Permalink
    Definition Classes
    SessionCatalog
  74. def listFunctions(db: String, pattern: String): Seq[(FunctionIdentifier, String)]

    Permalink
    Definition Classes
    SessionCatalog
  75. def listFunctions(db: String): Seq[(FunctionIdentifier, String)]

    Permalink
    Definition Classes
    SessionCatalog
  76. def listPartitionNames(tableName: TableIdentifier, partialSpec: Option[TablePartitionSpec]): Seq[String]

    Permalink
    Definition Classes
    SessionCatalog
  77. def listPartitions(tableName: TableIdentifier, partialSpec: Option[TablePartitionSpec]): Seq[CatalogTablePartition]

    Permalink
    Definition Classes
    SessionCatalog
  78. def listPartitionsByFilter(tableName: TableIdentifier, predicates: Seq[Expression]): Seq[CatalogTablePartition]

    Permalink
    Definition Classes
    SessionCatalog
  79. def listTables(db: String, pattern: String): Seq[TableIdentifier]

    Permalink
    Definition Classes
    SessionCatalog
  80. def listTables(db: String): Seq[TableIdentifier]

    Permalink
    Definition Classes
    SessionCatalog
  81. def loadFunctionResources(resources: Seq[FunctionResource]): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  82. def loadPartition(table: TableIdentifier, loadPath: String, spec: TablePartitionSpec, isOverwrite: Boolean, holdDDLTime: Boolean, inheritTableSpecs: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  83. def loadTable(table: TableIdentifier, loadPath: String, isOverwrite: Boolean, holdDDLTime: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  84. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  85. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  86. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  87. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  88. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  89. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  90. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  91. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  92. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  93. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  94. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  95. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  96. def lookupFunction(name: FunctionIdentifier, children: Seq[Expression]): Expression

    Permalink

    Return an Expression that represents the specified function, assuming it exists.

    Return an Expression that represents the specified function, assuming it exists.

    For a temporary function or a permanent function that has been loaded, this method will simply lookup the function through the FunctionRegistry and create an expression based on the builder.

    For a permanent function that has not been loaded, we will first fetch its metadata from the underlying external catalog. Then, we will load all resources associated with this function (i.e. jars and files). Finally, we create a function builder based on the function class and put the builder into the FunctionRegistry. The name of this function in the FunctionRegistry will be databaseName.functionName.

    Definition Classes
    SnappySessionCatalog → SessionCatalog
  97. def lookupFunctionInfo(name: FunctionIdentifier): ExpressionInfo

    Permalink
    Definition Classes
    SessionCatalog
  98. def lookupRelation(name: TableIdentifier, alias: Option[String]): LogicalPlan

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  99. def makeFunctionBuilder(funcName: String, className: String): FunctionBuilder

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  100. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  101. def normalizeField(f: StructField): StructField

    Permalink
    Attributes
    protected[org.apache.spark.sql]
  102. def normalizeSchema(schema: StructType): StructType

    Permalink
  103. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  104. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  105. def refreshTable(name: TableIdentifier): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  106. def renamePartitions(tableName: TableIdentifier, specs: Seq[TablePartitionSpec], newSpecs: Seq[TablePartitionSpec]): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  107. def renameTable(oldName: TableIdentifier, newName: TableIdentifier): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  108. def reset(): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  109. final def resolveRelation(tableIdent: TableIdentifier): LogicalPlan

    Permalink

    Lookup relation and resolve to a LogicalRelation if not a temporary view.

  110. final def resolveRelationWithAlias(tableIdent: TableIdentifier): LogicalPlan

    Permalink

    Lookup relation and resolve to a LogicalRelation if not a temporary view.

  111. final def resolveTableIdentifier(identifier: TableIdentifier): TableIdentifier

    Permalink

    Add schema to TableIdentifier if missing and format the name.

  112. def setCurrentDatabase(schema: String): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog → SessionCatalog
  113. val snappySession: SnappySession

    Permalink
  114. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  115. def tableExists(name: TableIdentifier): Boolean

    Permalink
    Definition Classes
    SessionCatalog
  116. val tempTables: HashMap[String, LogicalPlan]

    Permalink
    Attributes
    protected
    Definition Classes
    SessionCatalog
  117. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  118. def validateSchemaName(schemaName: String, checkForDefault: Boolean): Unit

    Permalink
    Attributes
    protected[org.apache.spark.sql]
  119. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  120. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  121. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from SessionCatalog

Inherited from internal.Logging

Inherited from AnyRef

Inherited from Any

Ungrouped