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
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 cartesianProductExecBufferSpillThreshold: Int

    Permalink
  10. def caseSensitiveAnalysis: Boolean

    Permalink
  11. def caseSensitiveInferenceMode: SQLConf.HiveCaseSensitiveInferenceMode.Value

    Permalink
  12. def cboEnabled: Boolean

    Permalink
  13. def checkpointLocation: Option[String]

    Permalink
  14. def clear(): Unit

    Permalink
  15. def clone(): SQLConf

    Permalink
    Definition Classes
    SQLConf → AnyRef
  16. def columnBatchSize: Int

    Permalink
  17. def columnNameOfCorruptRecord: String

    Permalink
  18. def constraintPropagationEnabled: Boolean

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

    Permalink

    Return whether a given key is set in this SQLConf.

  20. def convertCTAS: Boolean

    Permalink
  21. def copy(entries: (ConfigEntry[_], Any)*): SQLConf

    Permalink
  22. def crossJoinEnabled: Boolean

    Permalink
  23. def dataFramePivotMaxValues: Int

    Permalink
  24. def dataFrameRetainGroupColumns: Boolean

    Permalink
  25. def dataFrameSelfJoinAutoResolveAmbiguity: Boolean

    Permalink
  26. def defaultDataSourceName: String

    Permalink
  27. def defaultSizeInBytes: Long

    Permalink
  28. def enableRadixSort: Boolean

    Permalink
  29. def enableTwoLevelAggMap: Boolean

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  32. def escapedStringLiterals: Boolean

    Permalink
  33. def exchangeReuseEnabled: Boolean

    Permalink
  34. def fallBackToHdfsForStatsEnabled: Boolean

    Permalink
  35. def fileCommitProtocolClass: String

    Permalink
  36. def fileSinkLogCleanupDelay: Long

    Permalink
  37. def fileSinkLogCompactInterval: Int

    Permalink
  38. def fileSinkLogDeletion: Boolean

    Permalink
  39. def fileSourceLogCleanupDelay: Long

    Permalink
  40. def fileSourceLogCompactInterval: Int

    Permalink
  41. def fileSourceLogDeletion: Boolean

    Permalink
  42. def filesMaxPartitionBytes: Long

    Permalink
  43. def filesOpenCostInBytes: Long

    Permalink
  44. def filesourcePartitionFileCacheSize: Long

    Permalink
  45. def finalize(): Unit

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

    Permalink
  47. 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.

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  50. 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.

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

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

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

  54. 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" )
  55. def groupByAliases: Boolean

    Permalink
  56. def groupByOrdinal: Boolean

    Permalink
  57. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  58. def hiveThriftServerSingleSession: Boolean

    Permalink
  59. def ignoreCorruptFiles: Boolean

    Permalink
  60. def inMemoryPartitionPruning: Boolean

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

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

    Permalink
    Definition Classes
    Any
  63. def isParquetBinaryAsString: Boolean

    Permalink
  64. def isParquetINT64AsTimestampMillis: Boolean

    Permalink
  65. def isParquetINT96AsTimestamp: Boolean

    Permalink
  66. def isParquetSchemaMergingEnabled: Boolean

    Permalink
  67. def isParquetSchemaRespectSummaries: Boolean

    Permalink
  68. def isTraceEnabled(): Boolean

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

    Permalink
  70. def joinReorderCardWeight: Double

    Permalink
  71. def joinReorderDPStarFilter: Boolean

    Permalink
  72. def joinReorderDPThreshold: Int

    Permalink
  73. def joinReorderEnabled: Boolean

    Permalink
  74. def limitScaleUpFactor: Int

    Permalink
  75. def log: Logger

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
  88. def maxCaseBranchesForCodegen: Int

    Permalink
  89. def maxNestedViewDepth: Int

    Permalink
  90. def maxRecordsPerFile: Long

    Permalink
  91. def metastorePartitionPruning: Boolean

    Permalink
  92. def minBatchesToRetain: Int

    Permalink
  93. def minNumPostShufflePartitions: Int

    Permalink
  94. def ndvMaxError: Double

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

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

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

    Permalink
    Definition Classes
    AnyRef
  98. def numShufflePartitions: Int

    Permalink
  99. def objectAggSortBasedFallbackThreshold: Int

    Permalink
  100. def optimizerInSetConversionThreshold: Int

    Permalink
  101. def optimizerMaxIterations: Int

    Permalink

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

  102. def optimizerMetadataOnly: Boolean

    Permalink
  103. def orcFilterPushDown: Boolean

    Permalink
  104. def orderByOrdinal: Boolean

    Permalink
  105. def parallelPartitionDiscoveryParallelism: Int

    Permalink
  106. def parallelPartitionDiscoveryThreshold: Int

    Permalink
  107. def parquetCacheMetadata: Boolean

    Permalink
  108. def parquetCompressionCodec: String

    Permalink
  109. def parquetFilterPushDown: Boolean

    Permalink
  110. def parquetOutputCommitterClass: String

    Permalink
  111. def parquetVectorizedReaderEnabled: Boolean

    Permalink
  112. def partitionColumnTypeInferenceEnabled: Boolean

    Permalink
  113. def preferSortMergeJoin: Boolean

    Permalink
  114. def resolver: Resolver

    Permalink

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

  115. def runSQLonFile: Boolean

    Permalink
  116. def sessionLocalTimeZone: String

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

    Permalink

    Set the given Spark SQL configuration property.

  118. def setConf(props: Properties): Unit

    Permalink

    Set Spark SQL configuration properties.

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

    Permalink

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

  120. 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]
  121. def sortMergeJoinExecBufferSpillThreshold: Int

    Permalink
  122. def starSchemaDetection: Boolean

    Permalink
  123. def starSchemaFTRatio: Double

    Permalink
  124. def stateStoreMinDeltasForSnapshot: Int

    Permalink
  125. def streamingFileCommitProtocolClass: String

    Permalink
  126. def streamingMetricsEnabled: Boolean

    Permalink
  127. def streamingNoDataProgressEventInterval: Long

    Permalink
  128. def streamingPollingDelay: Long

    Permalink
  129. def streamingProgressRetention: Int

    Permalink
  130. def streamingSchemaInference: Boolean

    Permalink
  131. def subexpressionEliminationEnabled: Boolean

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

    Permalink
    Definition Classes
    AnyRef
  133. def tableRelationCacheSize: Int

    Permalink
  134. def targetPostShuffleInputSize: Long

    Permalink
  135. def toString(): String

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

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

    Permalink
  138. def useCompression: Boolean

    Permalink
  139. def useObjectHashAggregation: Boolean

    Permalink
  140. def variableSubstituteDepth: Int

    Permalink
  141. def variableSubstituteEnabled: Boolean

    Permalink
  142. def verifyPartitionPath: Boolean

    Permalink
  143. final def wait(): Unit

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

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

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

    Permalink
  147. def wholeStageEnabled: Boolean

    Permalink
  148. def wholeStageFallback: Boolean

    Permalink
  149. def wholeStageMaxNumFields: Int

    Permalink
  150. def windowExecBufferSpillThreshold: Int

    Permalink
  151. def writeLegacyParquetFormat: Boolean

    Permalink

Inherited from Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped