Object

org.apache.spark.sql.execution.columnar

ExternalStoreUtils

Related Doc: package columnar

Permalink

object ExternalStoreUtils extends Logging

Utility methods used by external storage layers.

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

Type Members

  1. class CaseInsensitiveMutableHashMap[T] extends Map[String, T] with Serializable

    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. final val BUCKETS: String("buckets")

    Permalink
  5. final val COLUMN_BATCH_SIZE: String("column_batch_size")

    Permalink
  6. final val COLUMN_BATCH_SIZE_TRANSIENT: String("column_batch_size_transient")

    Permalink
  7. final val COLUMN_MAX_DELTA_ROWS: String("column_max_delta_rows")

    Permalink
  8. final val COLUMN_MAX_DELTA_ROWS_TRANSIENT: String("column_max_delta_rows_transient")

    Permalink
  9. final val COMPRESSION_CODEC: String("compression")

    Permalink
  10. final val INDEX_NAME: String("index_name")

    Permalink
  11. final val INDEX_TYPE: String("index_type")

    Permalink
  12. final val KEY_COLUMNS: String("key_columns")

    Permalink
  13. final val PARTITION_BY: String("partition_by")

    Permalink
  14. final val RELATION_FOR_SAMPLE: String("relation_for_sample")

    Permalink
  15. final val REPLICATE: String("replicate")

    Permalink
  16. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  17. def checkPositiveNum(n: Int, propertyName: String): Int

    Permalink
  18. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  19. def codeGenOnExecutor(plan: CodegenSupport, child: CodegenSupportOnExecutor): (CodegenContext, CodeAndComment)

    Permalink

    Generates code for this subtree.

    Generates code for this subtree.

    Adapted from WholeStageCodegenExec to allow running on executors.

    returns

    the tuple of the codegen context and the actual generated source.

  20. val ddlOptions: Seq[String]

    Permalink
  21. def defaultColumnBatchSize(session: SparkSession): Int

    Permalink
  22. def defaultColumnMaxDeltaRows(session: SparkSession): Int

    Permalink
  23. def defaultStoreURL(clusterMode: ClusterMode): String

    Permalink
  24. def defaultStoreURL(sparkContext: Option[SparkContext]): String

    Permalink
  25. val emptyCIMutableMap: CaseInsensitiveMutableHashMap[String]

    Permalink
  26. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  28. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  29. def getAllPoolProperties(url: String, driver: String, poolProps: Map[String, String], hikariCP: Boolean, isEmbedded: Boolean): Map[String, String]

    Permalink
  30. def getAndSetTotalPartitions(session: SnappySession, parameters: Map[String, String], forManagedTable: Boolean, forColumnTable: Boolean = true, forSampleTable: Boolean = false): Int

    Permalink
  31. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  32. def getColumnMetadata(schema: StructType): List[com.gemstone.gemfire.internal.cache.ExternalTableMetaData.Column]

    Permalink
  33. def getConnection(id: String, connProperties: ConnectionProperties, forExecutor: Boolean, resetIsolationLevel: Boolean): Connection

    Permalink
  34. def getConnectionProperties(session: Option[SparkSession], url: String, driver: String, dialect: JdbcDialect, poolProps: Map[String, String], connProps: Properties, executorConnProps: Properties, hikariCP: Boolean): ConnectionProperties

    Permalink
  35. def getConnectionType(dialect: JdbcDialect): ConnectionType.Value

    Permalink
  36. def getCredentials(session: SparkSession, prefix: String = ""): (String, String)

    Permalink
  37. def getDriver(url: String, dialect: JdbcDialect): String

    Permalink
  38. def getExpandedGranteesIterator(grantees: Seq[String]): Iterator[String]

    Permalink
  39. def getExternalStoreOnExecutor(parameters: CaseInsensitiveMutableHashMap[String], partitions: Int, tableName: String, schema: StructType): ExternalStore

    Permalink
  40. def getExternalTableMetaData(qualifiedTable: String, container: GemFireContainer, checkColumnStore: Boolean): ExternalTableMetaData

    Permalink
  41. def getExternalTableMetaData(qualifiedTable: String): ExternalTableMetaData

    Permalink
  42. def getLdapGroupsForUser(userId: String): Array[String]

    Permalink
  43. def getSQLListener: AtomicReference[SQLListener]

    Permalink
  44. def getTableSchema(props: Map[String, String], forView: Boolean): Option[StructType]

    Permalink

    Get the table schema from CatalogTable.properties if present.

  45. def getTableSchema(schemaAsJson: String): StructType

    Permalink
  46. def handleRollback(rollback: () ⇒ Unit, finallyCode: () ⇒ Unit = null): Unit

    Permalink
  47. def handledFilter(f: Expression, indexedCols: Set[String]): Option[Expression]

    Permalink
  48. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  49. def init(): Unit

    Permalink
  50. def initializeLogIfNecessary(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  51. final def isDebugEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  52. def isExternalSchemaRelationProvider(provider: String): Boolean

    Permalink

    check if the DataSource implements ExternalSchemaRelationProvider

  53. final def isInfoEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  54. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  55. def isLocalMode(sparkContext: SparkContext): Boolean

    Permalink
  56. final def isTraceEnabled: Boolean

    Permalink
    Definition Classes
    Logging
  57. final var levelFlags: Int

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  58. def log: Logger

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

    Permalink
    Definition Classes
    Logging
  60. def logDebug(msg: ⇒ String): Unit

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

    Permalink
    Definition Classes
    Logging
  62. def logError(msg: ⇒ String): Unit

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

    Permalink
    Definition Classes
    Logging
  64. def logInfo(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  65. def logName: String

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

    Permalink
    Definition Classes
    Logging
  67. def logTrace(msg: ⇒ String): Unit

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

    Permalink
    Definition Classes
    Logging
  69. def logWarning(msg: ⇒ String): Unit

    Permalink
    Definition Classes
    Logging
  70. final var log_: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  71. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  74. def pruneSchema(fieldMap: Map[String, StructField], columns: Seq[String], columnType: String): StructType

    Permalink

    Prune all but the specified columns from the specified Catalyst schema.

    Prune all but the specified columns from the specified Catalyst schema.

    fieldMap

    - The Catalyst column name to metadata of the master table

    columns

    - The list of desired columns

    returns

    A Catalyst schema corresponding to columns in the given order.

  75. def registerBuiltinDrivers(): Unit

    Permalink
  76. def removeCachedObjects(table: String): Unit

    Permalink
  77. def removeCachedObjects(sqlContext: SQLContext, table: String): Unit

    Permalink
  78. def removeInternalPropsAndGetTable(parameters: Map[String, String], tableAsUpper: Boolean = true): String

    Permalink
  79. def removeSamplingOptions(parameters: Map[String, String]): Map[String, String]

    Permalink
  80. def resetLogger(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  81. def setStatementParameters(stmt: PreparedStatement, row: ArrayBuffer[Any]): Unit

    Permalink
  82. def sizeAsBytes(str: String, propertyName: String, minSize: Long, maxSize: Long): Long

    Permalink
  83. def sizeAsBytes(str: String, propertyName: String): Int

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

    Permalink
    Definition Classes
    AnyRef
  85. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  86. def unhandledFilter(f: Expression, indexedCols: Set[String]): Boolean

    Permalink
  87. def unhandledFilter(f: Expression): Boolean

    Permalink
  88. def validateAndGetAllProps(session: Option[SparkSession], parameters: CaseInsensitiveMutableHashMap[String]): ConnectionProperties

    Permalink
  89. final def wait(): Unit

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

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

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

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped