Class/Object

org.apache.spark.sql.internal

SQLConf

Related Docs: object SQLConf | package internal

Permalink

class SQLConf extends Serializable with Logging

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).

Linear Supertypes
Logging, Serializable, Serializable, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SQLConf
  2. Logging
  3. Serializable
  4. Serializable
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SQLConf()

    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 adaptiveExecutionEnabled: Boolean

    Permalink
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def autoBroadcastJoinThreshold: Long

    Permalink
  7. def broadcastTimeout: Int

    Permalink
  8. def bucketingEnabled: Boolean

    Permalink
  9. def caseSensitiveAnalysis: Boolean

    Permalink
  10. def caseSensitiveInferenceMode: SQLConf.HiveCaseSensitiveInferenceMode.Value

    Permalink
  11. def checkpointLocation: Option[String]

    Permalink
  12. def clear(): Unit

    Permalink
  13. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  14. def columnBatchSize: Int

    Permalink
  15. def columnNameOfCorruptRecord: String

    Permalink
  16. def contains(key: String): Boolean

    Permalink

    Return whether a given key is set in this SQLConf.

  17. def convertCTAS: Boolean

    Permalink
  18. def crossJoinEnabled: Boolean

    Permalink
  19. def dataFramePivotMaxValues: Int

    Permalink
  20. def dataFrameRetainGroupColumns: Boolean

    Permalink
  21. def dataFrameSelfJoinAutoResolveAmbiguity: Boolean

    Permalink
  22. def defaultDataSourceName: String

    Permalink
  23. def defaultSizeInBytes: Long

    Permalink
  24. def enableRadixSort: Boolean

    Permalink
  25. def enableTwoLevelAggMap: Boolean

    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 exchangeReuseEnabled: Boolean

    Permalink
  29. def fallBackToHdfsForStatsEnabled: Boolean

    Permalink
  30. def fileCommitProtocolClass: String

    Permalink
  31. def fileSinkLogCleanupDelay: Long

    Permalink
  32. def fileSinkLogCompactInterval: Int

    Permalink
  33. def fileSinkLogDeletion: Boolean

    Permalink
  34. def fileSourceLogCleanupDelay: Long

    Permalink
  35. def fileSourceLogCompactInterval: Int

    Permalink
  36. def fileSourceLogDeletion: Boolean

    Permalink
  37. def filesMaxPartitionBytes: Long

    Permalink
  38. def filesOpenCostInBytes: Long

    Permalink
  39. def filesourcePartitionFileCacheSize: Long

    Permalink
  40. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  41. def gatherFastStats: Boolean

    Permalink
  42. def getAllConfs: Map[String, String]

    Permalink

    Return all the configuration properties that have been set (i.e.

    Return all the configuration properties that have been set (i.e. not the default). This creates a new copy of the config properties in the form of a Map.

  43. def getAllDefinedConfs: Seq[(String, String, String)]

    Permalink

    Return all the configuration definitions that have been defined in SQLConf.

    Return all the configuration definitions that have been defined in SQLConf. Each definition contains key, defaultValue and doc.

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

    Permalink
    Definition Classes
    AnyRef → Any
  45. def getConf[T](entry: OptionalConfigEntry[T]): Option[T]

    Permalink

    Return the value of an optional Spark SQL configuration property for the given key.

    Return the value of an optional Spark SQL configuration property for the given key. If the key is not set yet, returns None.

  46. def getConf[T](entry: ConfigEntry[T]): T

    Permalink

    Return the value of Spark SQL configuration property for the given key.

    Return the value of Spark SQL configuration property for the given key. If the key is not set yet, return defaultValue in ConfigEntry.

  47. def getConf[T](entry: ConfigEntry[T], defaultValue: T): T

    Permalink

    Return the value of Spark SQL configuration property for the given key.

    Return the value of Spark SQL configuration property for the given key. If the key is not set yet, return defaultValue. This is useful when defaultValue in ConfigEntry is not the desired one.

  48. def getConfString(key: String, defaultValue: String): String

    Permalink

    Return the string value of Spark SQL configuration property for the given key.

    Return the string value of Spark SQL configuration property for the given key. If the key is not set yet, return defaultValue.

  49. def getConfString(key: String): String

    Permalink

    Return the value of Spark SQL configuration property for the given key.

    Return the value of Spark SQL configuration property for the given key.

    Annotations
    @throws( "if key is not set" )
  50. def groupByOrdinal: Boolean

    Permalink
  51. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  52. def ignoreCorruptFiles: Boolean

    Permalink
  53. def inMemoryPartitionPruning: Boolean

    Permalink
  54. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

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

    Permalink
    Definition Classes
    Any
  56. def isParquetBinaryAsString: Boolean

    Permalink
  57. def isParquetINT96AsTimestamp: Boolean

    Permalink
  58. def isParquetSchemaMergingEnabled: Boolean

    Permalink
  59. def isParquetSchemaRespectSummaries: Boolean

    Permalink
  60. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  61. def isUnsupportedOperationCheckEnabled: Boolean

    Permalink
  62. def limitScaleUpFactor: Int

    Permalink
  63. def log: Logger

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  75. def manageFilesourcePartitions: Boolean

    Permalink
  76. def maxCaseBranchesForCodegen: Int

    Permalink
  77. def metastorePartitionPruning: Boolean

    Permalink
  78. def minBatchesToRetain: Int

    Permalink
  79. def minNumPostShufflePartitions: Int

    Permalink
  80. def ndvMaxError: Double

    Permalink
  81. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  84. def numShufflePartitions: Int

    Permalink
  85. def optimizerInSetConversionThreshold: Int

    Permalink
  86. def optimizerMaxIterations: Int

    Permalink

    ************************ Spark SQL Params/Hints *******************

  87. def optimizerMetadataOnly: Boolean

    Permalink
  88. def orcFilterPushDown: Boolean

    Permalink
  89. def orderByOrdinal: Boolean

    Permalink
  90. def parallelPartitionDiscoveryParallelism: Int

    Permalink
  91. def parallelPartitionDiscoveryThreshold: Int

    Permalink
  92. def parquetCacheMetadata: Boolean

    Permalink
  93. def parquetCompressionCodec: String

    Permalink
  94. def parquetFilterPushDown: Boolean

    Permalink
  95. def parquetOutputCommitterClass: String

    Permalink
  96. def parquetVectorizedReaderEnabled: Boolean

    Permalink
  97. def partitionColumnTypeInferenceEnabled: Boolean

    Permalink
  98. def preferSortMergeJoin: Boolean

    Permalink
  99. def resolver: Resolver

    Permalink

    Returns the Resolver for the current configuration, which can be used to determine if two identifiers are equal.

  100. def runSQLonFile: Boolean

    Permalink
  101. def setConf[T](entry: ConfigEntry[T], value: T): Unit

    Permalink

    Set the given Spark SQL configuration property.

  102. def setConf(props: Properties): Unit

    Permalink

    Set Spark SQL configuration properties.

  103. def setConfString(key: String, value: String): Unit

    Permalink

    Set the given Spark SQL configuration property using a string value.

  104. val settings: Map[String, String]

    Permalink

    Only low degree of contention is expected for conf, thus NOT using ConcurrentHashMap.

    Only low degree of contention is expected for conf, thus NOT using ConcurrentHashMap.

    Attributes
    protected[org.apache.spark]
  105. def stateStoreMinDeltasForSnapshot: Int

    Permalink
  106. def streamingFileCommitProtocolClass: String

    Permalink
  107. def streamingMetricsEnabled: Boolean

    Permalink
  108. def streamingNoDataProgressEventInterval: Long

    Permalink
  109. def streamingPollingDelay: Long

    Permalink
  110. def streamingProgressRetention: Int

    Permalink
  111. def streamingSchemaInference: Boolean

    Permalink
  112. def subexpressionEliminationEnabled: Boolean

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

    Permalink
    Definition Classes
    AnyRef
  114. def targetPostShuffleInputSize: Long

    Permalink
  115. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  116. def unsetConf(entry: ConfigEntry[_]): Unit

    Permalink
  117. def unsetConf(key: String): Unit

    Permalink
  118. def useCompression: Boolean

    Permalink
  119. def variableSubstituteDepth: Int

    Permalink
  120. def variableSubstituteEnabled: Boolean

    Permalink
  121. def verifyPartitionPath: Boolean

    Permalink
  122. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  125. def warehousePath: String

    Permalink
  126. def wholeStageEnabled: Boolean

    Permalink
  127. def wholeStageFallback: Boolean

    Permalink
  128. def wholeStageMaxNumFields: Int

    Permalink
  129. def writeLegacyParquetFormat: Boolean

    Permalink

Inherited from Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped