org.apache.spark.sql.columnar

ExternalStoreUtils

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
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

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

Value Members

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

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

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

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final val BUCKETS: String("BUCKETS")

  7. final val DEFAULT_SAMPLE_TABLE_BUCKETS: String("53")

  8. final val DEFAULT_SAMPLE_TABLE_BUCKETS_LOCAL_MODE: String("7")

  9. final val DEFAULT_TABLE_BUCKETS: String("113")

  10. final val DEFAULT_TABLE_BUCKETS_LOCAL_MODE: String("11")

  11. final val PARTITION_BY: String("PARTITION_BY")

  12. final val REPLICATE: String("REPLICATE")

  13. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  14. final def cachedBatchesToRows(cachedBatches: Iterator[CachedBatch], requestedColumnIndices: IndexedSeq[Int], requestedColumnDataTypes: IndexedSeq[DataType], schema: StructType): Iterator[InternalRow]

  15. final def cachedBatchesToRows(cachedBatches: Iterator[CachedBatch], requestedColumns: Array[String], schema: StructType): Iterator[InternalRow]

  16. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  17. def defaultStoreURL(sc: SparkContext): String

  18. final def eq(arg0: AnyRef): Boolean

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

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

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

  22. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  23. def getConnection(url: String, connProperties: Properties, driverDialect: JdbcDialect, isLoner: Boolean): Connection

  24. def getConnectionType(url: String): ConnectionType.Value

  25. def getConnector(id: String, driver: String, dialect: JdbcDialect, poolProps: Map[String, String], connProps: Properties, hikariCP: Boolean): () ⇒ Connection

  26. def getDriver(url: String, dialect: JdbcDialect): String

  27. def getInsertString(table: String, userSchema: StructType): String

  28. def getInsertStringWithColumnName(table: String, rddSchema: StructType): String

  29. def getJDBCType(dialect: JdbcDialect, dataType: DataType): Int

  30. def getNullTypes(url: String, schema: StructType): Array[Int]

  31. def getPutString(table: String, userSchema: StructType): String

  32. def getTotalPartitions(sc: SparkContext, parameters: Map[String, String], forManagedTable: Boolean, forColumnTable: Boolean = true, forSampleTable: Boolean = false): Int

  33. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  34. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  35. def isShellOrLocalMode(sparkContext: SparkContext): Boolean

  36. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  37. def log: Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  44. def logName: String

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

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

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

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

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

    Definition Classes
    AnyRef
  50. final def notify(): Unit

    Definition Classes
    AnyRef
  51. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  52. def pruneSchema(fieldMap: Map[String, StructField], columns: Array[String]): StructType

    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.

  53. def removeInternalProps(parameters: Map[String, String]): String

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

  55. def setStatementParameters(stmt: PreparedStatement, row: ArrayBuffer[Any]): Unit

  56. def setStatementParameters(stmt: PreparedStatement, columns: Array[StructField], row: Row, dialect: JdbcDialect): Unit

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

    Definition Classes
    AnyRef
  58. def toString(): String

    Definition Classes
    AnyRef → Any
  59. def validateAndGetAllProps(sc: SparkContext, parameters: Map[String, String]): ConnectionProperties

  60. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped