Class/Object

org.apache.spark.sql.internal

SQLConf

Related Docs: object SQLConf | package internal

Permalink

class SQLConf extends Serializable with internal.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
internal.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 constraintPropagationEnabled: Boolean

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

    Permalink

    Return whether a given key is set in this SQLConf.

  18. def convertCTAS: Boolean

    Permalink
  19. def crossJoinEnabled: Boolean

    Permalink
  20. def dataFramePivotMaxValues: Int

    Permalink
  21. def dataFrameRetainGroupColumns: Boolean

    Permalink
  22. def dataFrameSelfJoinAutoResolveAmbiguity: Boolean

    Permalink
  23. def defaultDataSourceName: String

    Permalink
  24. def defaultSizeInBytes: Long

    Permalink
  25. def enableRadixSort: Boolean

    Permalink
  26. def enableTwoLevelAggMap: Boolean

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  29. def exchangeReuseEnabled: Boolean

    Permalink
  30. def fallBackToHdfsForStatsEnabled: Boolean

    Permalink
  31. def fileCommitProtocolClass: String

    Permalink
  32. def fileSinkLogCleanupDelay: Long

    Permalink
  33. def fileSinkLogCompactInterval: Int

    Permalink
  34. def fileSinkLogDeletion: Boolean

    Permalink
  35. def fileSourceLogCleanupDelay: Long

    Permalink
  36. def fileSourceLogCompactInterval: Int

    Permalink
  37. def fileSourceLogDeletion: Boolean

    Permalink
  38. def filesMaxPartitionBytes: Long

    Permalink
  39. def filesOpenCostInBytes: Long

    Permalink
  40. def filesourcePartitionFileCacheSize: Long

    Permalink
  41. def finalize(): Unit

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

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

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

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

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

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

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

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

  50. 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" )
  51. def groupByOrdinal: Boolean

    Permalink
  52. def hashCode(): Int

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

    Permalink
  54. def inMemoryPartitionPruning: Boolean

    Permalink
  55. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean = false): Boolean

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

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

    Permalink
    Definition Classes
    Any
  58. def isParquetBinaryAsString: Boolean

    Permalink
  59. def isParquetINT96AsTimestamp: Boolean

    Permalink
  60. def isParquetSchemaMergingEnabled: Boolean

    Permalink
  61. def isParquetSchemaRespectSummaries: Boolean

    Permalink
  62. def isTraceEnabled(): Boolean

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

    Permalink
  64. def limitScaleUpFactor: Int

    Permalink
  65. def log: Logger

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
  78. def maxBatchesToRetainInMemory: Int

    Permalink
  79. def maxCaseBranchesForCodegen: Int

    Permalink
  80. def metastorePartitionPruning: Boolean

    Permalink
  81. def minBatchesToRetain: Int

    Permalink
  82. def minNumPostShufflePartitions: Int

    Permalink
  83. def ndvMaxError: Double

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

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

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

    Permalink
    Definition Classes
    AnyRef
  87. def numShufflePartitions: Int

    Permalink
  88. def optimizerInSetConversionThreshold: Int

    Permalink
  89. def optimizerMaxIterations: Int

    Permalink

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

  90. def optimizerMetadataOnly: Boolean

    Permalink
  91. def orcFilterPushDown: Boolean

    Permalink
  92. def orderByOrdinal: Boolean

    Permalink
  93. def parallelPartitionDiscoveryParallelism: Int

    Permalink
  94. def parallelPartitionDiscoveryThreshold: Int

    Permalink
  95. def parquetCacheMetadata: Boolean

    Permalink
  96. def parquetCompressionCodec: String

    Permalink
  97. def parquetFilterPushDown: Boolean

    Permalink
  98. def parquetOutputCommitterClass: String

    Permalink
  99. def parquetVectorizedReaderEnabled: Boolean

    Permalink
  100. def partitionColumnTypeInferenceEnabled: Boolean

    Permalink
  101. def preferSortMergeJoin: Boolean

    Permalink
  102. def resolver: Resolver

    Permalink

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

  103. def runSQLonFile: Boolean

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

    Permalink

    Set the given Spark SQL configuration property.

  105. def setConf(props: Properties): Unit

    Permalink

    Set Spark SQL configuration properties.

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

    Permalink

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

  107. 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]
  108. def sortBeforeRepartition: Boolean

    Permalink
  109. def stateStoreMinDeltasForSnapshot: Int

    Permalink
  110. def streamingFileCommitProtocolClass: String

    Permalink
  111. def streamingMetricsEnabled: Boolean

    Permalink
  112. def streamingNoDataProgressEventInterval: Long

    Permalink
  113. def streamingPollingDelay: Long

    Permalink
  114. def streamingProgressRetention: Int

    Permalink
  115. def streamingSchemaInference: Boolean

    Permalink
  116. def streamingUIRunningQueriesDisplayLimit: Int

    Permalink
  117. def streamingUITrendsMaxSampleSize: Int

    Permalink
  118. def subexpressionEliminationEnabled: Boolean

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

    Permalink
    Definition Classes
    AnyRef
  120. def targetPostShuffleInputSize: Long

    Permalink
  121. def toString(): String

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

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

    Permalink
  124. def useCompression: Boolean

    Permalink
  125. def variableSubstituteDepth: Int

    Permalink
  126. def variableSubstituteEnabled: Boolean

    Permalink
  127. def verifyPartitionPath: Boolean

    Permalink
  128. final def wait(): Unit

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

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

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

    Permalink
  132. def wholeStageEnabled: Boolean

    Permalink
  133. def wholeStageFallback: Boolean

    Permalink
  134. def wholeStageMaxNumFields: Int

    Permalink
  135. def writeLegacyParquetFormat: Boolean

    Permalink

Inherited from internal.Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped