Class

org.apache.spark.sql.hive

SnappyAQPSessionCatalog

Related Doc: package hive

Permalink

class SnappyAQPSessionCatalog extends SnappySessionCatalog

Linear Supertypes
SnappySessionCatalog, SessionCatalog, internal.Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SnappyAQPSessionCatalog
  2. SnappySessionCatalog
  3. SessionCatalog
  4. Logging
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SnappyAQPSessionCatalog(_externalCatalog: SnappyExternalCatalog, _session: SnappySession, globalViewManager: 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
    Definition Classes
    SnappySessionCatalog
  5. def addSampleDataFrame(base: LogicalPlan, sample: LogicalPlan, name: String = ""): Unit

    Permalink
  6. def alterDatabase(schemaDefinition: CatalogDatabase): Unit

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

    Permalink

    Alter one or many table partitions whose specs that match those specified in parts, assuming the partitions exist.

    Alter one or many table partitions whose specs that match those specified in parts, assuming the partitions exist.

    If no database is specified, assume the table is in the current database.

    Note: If the underlying implementation does not support altering a certain field, this becomes a no-op.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  8. def alterTable(table: CatalogTable): Unit

    Permalink

    Alter the metadata of an existing metastore table identified by tableDefinition.

    Alter the metadata of an existing metastore table identified by tableDefinition.

    If no database is specified in tableDefinition, assume the table is in the current database.

    Note: If the underlying implementation does not support altering a certain field, this becomes a no-op.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  9. def alterTempViewDefinition(name: TableIdentifier, viewDefinition: LogicalPlan): Boolean

    Permalink

    Alter the definition of a local/global temp view matching the given name, returns true if a temp view is matched and altered, false otherwise.

    Alter the definition of a local/global temp view matching the given name, returns true if a temp view is matched and altered, false otherwise.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  10. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  11. val cachedDataSourceTables: LoadingCache[TableIdentifier, LogicalPlan]

    Permalink

    A cache of Spark SQL data source tables that have been accessed.

    A cache of Spark SQL data source tables that have been accessed.

    Attributes
    protected[org.apache.spark.sql]
    Definition Classes
    SnappySessionCatalog
  12. final def checkBuiltinCatalog(tableIdent: TableIdentifier): Boolean

    Permalink

    Return true if the given table needs to be checked in the builtin catalog rather than the external hive catalog (if enabled).

    Return true if the given table needs to be checked in the builtin catalog rather than the external hive catalog (if enabled).

    Attributes
    protected
    Definition Classes
    SnappySessionCatalog
  13. def clearTempTables(): Unit

    Permalink

    Drop all existing temporary tables.

    Drop all existing temporary tables. For testing only.

    Definition Classes
    SessionCatalog
  14. def clone(): AnyRef

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

    Permalink
    Definition Classes
    SnappySessionCatalog
  16. 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]
    Definition Classes
    SnappySessionCatalog
  17. def createDatabase(schemaDefinition: CatalogDatabase, ignoreIfExists: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  18. def createFunction(funcDefinition: CatalogFunction, ignoreIfExists: Boolean): Unit

    Permalink

    Create a metastore function in the database specified in funcDefinition.

    Create a metastore function in the database specified in funcDefinition. If no such database is specified, create it in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  19. def createGlobalTempView(name: String, viewDefinition: LogicalPlan, overrideIfExists: Boolean): Unit

    Permalink

    Create a global temporary view.

    Create a global temporary view.

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

    Permalink

    Create partitions in an existing table, assuming it exists.

    Create partitions in an existing table, assuming it exists. If no database is specified, assume the table is in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  21. def createPolicy(policyIdent: TableIdentifier, targetTable: TableIdentifier, policyFor: String, policyApplyTo: Seq[String], expandedPolicyApplyTo: Seq[String], currentUser: String, filterString: String): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog
  22. def createTable(table: CatalogTable, ignoreIfExists: Boolean): Unit

    Permalink

    Create a metastore table in the database specified in tableDefinition.

    Create a metastore table in the database specified in tableDefinition. If no such database is specified, create it in the current database.

    Definition Classes
    SnappyAQPSessionCatalogSnappySessionCatalogSessionCatalog
  23. def createTempFunction(name: String, info: ExpressionInfo, funcDefinition: FunctionBuilder, ignoreIfExists: Boolean): Unit

    Permalink

    Create a temporary function.

    Create a temporary function. This assumes no database is specified in funcDefinition.

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

    Permalink

    Create a local temporary view.

    Create a local temporary view.

    Definition Classes
    SessionCatalog
  25. var currentDb: String

    Permalink
    Attributes
    protected
    Definition Classes
    SessionCatalog
  26. def databaseExists(schema: String): Boolean

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  27. val defaultSchemaName: String

    Permalink
    Definition Classes
    SnappySessionCatalog
  28. def defaultTablePath(tableIdent: TableIdentifier): String

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

    Permalink

    Test only method

    Test only method

    Definition Classes
    SnappySessionCatalog
  30. def dropAllSchemaObjects(schema: 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.

    Definition Classes
    SnappySessionCatalog
  31. def dropDatabase(schema: String, ignoreIfNotExists: Boolean, cascade: Boolean): Unit

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  32. def dropFromTemporaryBaseTable(table: CatalogTable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyAQPSessionCatalogSnappySessionCatalog
  33. def dropFunction(name: FunctionIdentifier, ignoreIfNotExists: Boolean): Unit

    Permalink

    Drop a metastore function.

    Drop a metastore function. If no database is specified, assume the function is in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  34. def dropGlobalTempView(name: String): Boolean

    Permalink

    Drop a global temporary view.

    Drop a global temporary view.

    Returns true if this view is dropped successfully, false otherwise.

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

    Permalink

    Drop partitions from a table, assuming they exist.

    Drop partitions from a table, assuming they exist. If no database is specified, assume the table is in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  36. def dropTable(tableIdent: TableIdentifier, ignoreIfNotExists: Boolean, purge: Boolean): Unit

    Permalink

    Drop a table.

    Drop a table.

    If a database is specified in name, this will drop the table from that database. If no database is specified, this will first attempt to drop a temporary table with the same name, then, if that does not exist, drop the table from the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  37. def dropTempFunction(name: String, ignoreIfNotExists: Boolean): Unit

    Permalink

    Drop a temporary function.

    Drop a temporary function.

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

    Permalink

    Drop a local temporary view.

    Drop a local temporary view.

    Returns true if this view is dropped successfully, false otherwise.

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

    Permalink
    Attributes
    protected
    Definition Classes
    SnappyAQPSessionCatalogSnappySessionCatalog
  40. final def eq(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    SnappySessionCatalog
  43. def failFunctionLookup(name: String): Nothing

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  44. def finalize(): Unit

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

    Permalink

    Format schema name.

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

    Definition Classes
    SnappySessionCatalogSessionCatalog
  46. final def formatName(name: String): String

    Permalink
    Definition Classes
    SnappySessionCatalog
  47. def formatTableName(name: String): String

    Permalink

    Format table name.

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

    Definition Classes
    SnappySessionCatalogSessionCatalog
  48. def functionExists(name: FunctionIdentifier): Boolean

    Permalink

    Check if the specified function exists.

    Check if the specified function exists.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  49. final def getClass(): Class[_]

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

    Permalink
    Definition Classes
    SnappySessionCatalog
  51. final def getCombinedPolicyFilterForNativeTable(rlsRelation: RowLevelSecurityRelation, wrappingLogicalRelation: Option[LogicalRelation]): Option[Filter]

    Permalink
    Definition Classes
    SnappySessionCatalog
  52. def getCurrentDatabase: String

    Permalink
    Definition Classes
    SessionCatalog
  53. final def getCurrentSchema: String

    Permalink
    Definition Classes
    SnappySessionCatalog
  54. def getDataSourceRelations[T](tableType: Type): Seq[T]

    Permalink
    Definition Classes
    SnappySessionCatalog
  55. def getDatabaseMetadata(schema: String): CatalogDatabase

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  56. def getDefaultDBPath(db: String): String

    Permalink

    Get the path for creating a non-default database when database location is not provided by users.

    Get the path for creating a non-default database when database location is not provided by users.

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

    Permalink

    Retrieve the metadata of a metastore function.

    Retrieve the metadata of a metastore function.

    If a database is specified in name, this will return the function in that database. If no database is specified, this will return the function in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  58. def getGlobalTempView(name: String): Option[LogicalPlan]

    Permalink

    Return a global temporary view exactly as it was stored.

    Return a global temporary view exactly as it was stored.

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

    Permalink

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

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

    Definition Classes
    SnappySessionCatalog
  60. def getKeyColumnsAndPositions(table: String): Seq[(catalog.Column, Int)]

    Permalink

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

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

    Definition Classes
    SnappySessionCatalog
  61. def getPartition(table: TableIdentifier, spec: TablePartitionSpec): CatalogTablePartition

    Permalink

    Retrieve the metadata of a table partition, assuming it exists.

    Retrieve the metadata of a table partition, assuming it exists. If no database is specified, assume the table is in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  62. def getSampleRelations(baseTable: TableIdentifier): Seq[(LogicalPlan, String)]

    Permalink

    Return the set of samples for a given table that are tracked in catalog and are not temporary.

    Return the set of samples for a given table that are tracked in catalog and are not temporary.

    Definition Classes
    SnappyAQPSessionCatalogSnappySessionCatalog
  63. def getSamples(base: LogicalPlan): Seq[LogicalPlan]

    Permalink

    Return the set of temporary samples for a given table that are not tracked in catalog.

    Return the set of temporary samples for a given table that are not tracked in catalog.

    Definition Classes
    SnappyAQPSessionCatalogSnappySessionCatalog
  64. final def getSchemaName(identifier: IdentifierWithDatabase): String

    Permalink
    Definition Classes
    SnappySessionCatalog
  65. def getTableMetadata(name: TableIdentifier): CatalogTable

    Permalink

    Retrieve the metadata of an existing permanent table/view.

    Retrieve the metadata of an existing permanent table/view. If no database is specified, assume the table/view is in the current database. If the specified table/view is not found in the database then a NoSuchTableException is thrown.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  66. def getTableMetadataOption(name: TableIdentifier): Option[CatalogTable]

    Permalink

    Retrieve the metadata of an existing metastore table.

    Retrieve the metadata of an existing metastore table. If no database is specified, assume the table is in the current database. If the specified table is not found in the database then return None if it doesn't exist.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  67. def getTempView(name: String): Option[LogicalPlan]

    Permalink

    Return a local temporary view exactly as it was stored.

    Return a local temporary view exactly as it was stored.

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

    Permalink

    Retrieve the metadata of an existing temporary view or permanent table/view.

    Retrieve the metadata of an existing temporary view or permanent table/view.

    If a database is specified in name, this will return the metadata of table/view in that database. If no database is specified, this will first attempt to get the metadata of a temporary view with the same name, then, if that does not exist, return the metadata of table/view in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  69. val hadoopConf: Configuration

    Permalink
    Definition Classes
    SnappySessionCatalog
  70. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  71. final lazy val hiveSessionCatalog: HiveSessionCatalog

    Permalink

    Fallback session state to lookup from external hive catalog in case "snappydata.sql.hive.enabled" is set on the session.

    Fallback session state to lookup from external hive catalog in case "snappydata.sql.hive.enabled" is set on the session.

    Attributes
    protected
    Definition Classes
    SnappySessionCatalog
  72. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean = false): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  73. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  74. def invalidate(resolved: TableIdentifier, sessionOnly: Boolean = false): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog
  75. def invalidateAll(sessionOnly: Boolean = false): Unit

    Permalink
    Definition Classes
    SnappySessionCatalog
  76. final def isInstanceOf[T0]: Boolean

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

    Permalink
    Definition Classes
    SnappySessionCatalog
  78. def isTemporaryFunction(name: FunctionIdentifier): Boolean

    Permalink

    Returns whether it is a temporary function.

    Returns whether it is a temporary function. If not existed, returns false.

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

    Permalink

    Return whether a table with the specified name is a temporary table.

    Return whether a table with the specified name is a temporary table.

    Note: The temporary table cache is checked only when database is not explicitly specified.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  80. def isTraceEnabled(): Boolean

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

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  82. def listDatabases(): Seq[String]

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  83. def listFunctions(schema: String, pattern: String): Seq[(FunctionIdentifier, String)]

    Permalink

    List all matching functions in the specified database, including temporary functions.

    List all matching functions in the specified database, including temporary functions. This returns the function identifier and the scope in which it was defined (system or user defined).

    Definition Classes
    SnappySessionCatalogSessionCatalog
  84. def listFunctions(db: String): Seq[(FunctionIdentifier, String)]

    Permalink

    List all functions in the specified database, including temporary functions.

    List all functions in the specified database, including temporary functions. This returns the function identifier and the scope in which it was defined (system or user defined).

    Definition Classes
    SessionCatalog
  85. def listPartitionNames(tableName: TableIdentifier, partialSpec: Option[TablePartitionSpec] = None): Seq[String]

    Permalink

    List the names of all partitions that belong to the specified table, assuming it exists.

    List the names of all partitions that belong to the specified table, assuming it exists.

    A partial partition spec may optionally be provided to filter the partitions returned. For instance, if there exist partitions (a='1', b='2'), (a='1', b='3') and (a='2', b='4'), then a partial spec of (a='1') will return the first two only.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  86. def listPartitions(tableName: TableIdentifier, partialSpec: Option[TablePartitionSpec]): Seq[CatalogTablePartition]

    Permalink

    List the metadata of all partitions that belong to the specified table, assuming it exists.

    List the metadata of all partitions that belong to the specified table, assuming it exists.

    A partial partition spec may optionally be provided to filter the partitions returned. For instance, if there exist partitions (a='1', b='2'), (a='1', b='3') and (a='2', b='4'), then a partial spec of (a='1') will return the first two only.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  87. def listPartitionsByFilter(tableName: TableIdentifier, predicates: Seq[Expression]): Seq[CatalogTablePartition]

    Permalink

    List the metadata of partitions that belong to the specified table, assuming it exists, that satisfy the given partition-pruning predicate expressions.

    List the metadata of partitions that belong to the specified table, assuming it exists, that satisfy the given partition-pruning predicate expressions.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  88. def listTables(schema: String, pattern: String): Seq[TableIdentifier]

    Permalink

    List all matching tables in the specified database, including local temporary tables.

    List all matching tables in the specified database, including local temporary tables.

    Note that, if the specified database is global temporary view database, we will list global temporary views.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  89. def listTables(db: String): Seq[TableIdentifier]

    Permalink

    List all tables in the specified database, including local temporary tables.

    List all tables in the specified database, including local temporary tables.

    Note that, if the specified database is global temporary view database, we will list global temporary views.

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

    Permalink

    Loads resources such as JARs and Files for a function.

    Loads resources such as JARs and Files for a function. Every resource is represented by a tuple (resource type, resource uri).

    Definition Classes
    SnappySessionCatalogSessionCatalog
  91. def loadPartition(table: TableIdentifier, loadPath: String, spec: TablePartitionSpec, isOverwrite: Boolean, holdDDLTime: Boolean, inheritTableSpecs: Boolean): Unit

    Permalink

    Load files stored in given path into the partition of an existing metastore table.

    Load files stored in given path into the partition of an existing metastore table. If no database is specified, assume the table is in the current database. If the specified table is not found in the database then a NoSuchTableException is thrown.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  92. def loadTable(table: TableIdentifier, loadPath: String, isOverwrite: Boolean, holdDDLTime: Boolean): Unit

    Permalink

    Load files stored in given path into an existing metastore table.

    Load files stored in given path into an existing metastore table. If no database is specified, assume the table is in the current database. If the specified table is not found in the database then a NoSuchTableException is thrown.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  93. def log: Logger

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  105. 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
    SnappySessionCatalogSessionCatalog
  106. def lookupFunctionInfo(name: FunctionIdentifier): ExpressionInfo

    Permalink

    Look up the ExpressionInfo associated with the specified function, assuming it exists.

    Look up the ExpressionInfo associated with the specified function, assuming it exists.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  107. def lookupRelation(name: TableIdentifier, alias: Option[String]): LogicalPlan

    Permalink

    Return a LogicalPlan that represents the given table or view.

    Return a LogicalPlan that represents the given table or view.

    If a database is specified in name, this will return the table/view from that database. If no database is specified, this will first attempt to return a temporary table/view with the same name, then, if that does not exist, return the table/view from the current database.

    Note that, the global temp view database is also valid here, this will return the global temp view matching the given name.

    If the relation is a view, the relation will be wrapped in a SubqueryAlias which will track the name of the view.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  108. def lookupTopK(topKName: String): Option[(TopKWrapper, RDD[(Int, TopK)])]

    Permalink
  109. def makeFunctionBuilder(funcName: String, className: String): FunctionBuilder

    Permalink

    Construct a FunctionBuilder based on the provided class that represents a function.

    Construct a FunctionBuilder based on the provided class that represents a function.

    This performs reflection to decide what type of Expression to return in the builder.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  110. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  111. final def notify(): Unit

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

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

    Permalink

    Refresh the cache entry for a metastore table, if any.

    Refresh the cache entry for a metastore table, if any.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  114. def registerTopK(topKWrapper: TopKWrapper, rdd: RDD[(Int, TopK)], ifExists: Boolean, overwrite: Boolean): Boolean

    Permalink
  115. def renamePartitions(tableName: TableIdentifier, specs: Seq[TablePartitionSpec], newSpecs: Seq[TablePartitionSpec]): Unit

    Permalink

    Override the specs of one or many existing table partitions, assuming they exist.

    Override the specs of one or many existing table partitions, assuming they exist.

    This assumes index i of specs corresponds to index i of newSpecs. If no database is specified, assume the table is in the current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  116. def renameTable(old: TableIdentifier, newName: TableIdentifier): Unit

    Permalink

    Rename a table.

    Rename a table.

    If a database is specified in oldName, this will rename the table in that database. If no database is specified, this will first attempt to rename a temporary table with the same name, then, if that does not exist, rename the table in the current database.

    This assumes the database specified in newName matches the one in oldName.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  117. def reset(): Unit

    Permalink

    Drop all existing databases (except "default"), tables, partitions and functions, and set the current database to "default".

    Drop all existing databases (except "default"), tables, partitions and functions, and set the current database to "default".

    This is mainly used for tests.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  118. final def resolveExistingTable(name: String): TableIdentifier

    Permalink

    Convert a table name to TableIdentifier for an existing table.

    Convert a table name to TableIdentifier for an existing table.

    Definition Classes
    SnappySessionCatalog
  119. final def resolveRelation(tableIdent: TableIdentifier): LogicalPlan

    Permalink

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

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

    Definition Classes
    SnappySessionCatalog
  120. final def resolveRelationWithAlias(tableIdent: TableIdentifier, alias: Option[String] = None): LogicalPlan

    Permalink

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

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

    Definition Classes
    SnappySessionCatalog
  121. final def resolveTableIdentifier(identifier: TableIdentifier): TableIdentifier

    Permalink

    Add schema to TableIdentifier if missing and format the name.

    Add schema to TableIdentifier if missing and format the name.

    Definition Classes
    SnappySessionCatalog
  122. def setCurrentDatabase(schema: String): Unit

    Permalink
    Definition Classes
    SnappySessionCatalogSessionCatalog
  123. val snappySession: SnappySession

    Permalink
    Definition Classes
    SnappySessionCatalog
  124. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink

    Return whether a table/view with the specified name exists.

    Return whether a table/view with the specified name exists. If no database is specified, check with current database.

    Definition Classes
    SnappySessionCatalogSessionCatalog
  126. val tempTables: HashMap[String, LogicalPlan]

    Permalink

    List of temporary tables, mapping from table name to their logical plan.

    List of temporary tables, mapping from table name to their logical plan.

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

    Permalink
    Definition Classes
    AnyRef → Any
  128. def unregisterTopK(topKName: String): Unit

    Permalink
  129. def validateSchemaName(schemaName: String, checkForDefault: Boolean): Unit

    Permalink
    Attributes
    protected[org.apache.spark.sql]
    Definition Classes
    SnappySessionCatalog
  130. final def wait(): Unit

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

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

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

Inherited from SnappySessionCatalog

Inherited from SessionCatalog

Inherited from internal.Logging

Inherited from AnyRef

Inherited from Any

Ungrouped