org.apache.spark.sql.catalyst

SimpleCatalystConf

case class SimpleCatalystConf(caseSensitiveAnalysis: Boolean, orderByOrdinal: Boolean = true, groupByOrdinal: Boolean = true, optimizerMaxIterations: Int = 100, optimizerInSetConversionThreshold: Int = 10, maxCaseBranchesForCodegen: Int = 20, runSQLonFile: Boolean = true, crossJoinEnabled: Boolean = false, warehousePath: String = "/user/hive/warehouse") extends SQLConf with Product with Serializable

A SQLConf that can be used for local testing. This class is only here to minimize the change for ticket SPARK-19944 (moves SQLConf from sql/core to sql/catalyst). This class should eventually be removed (test cases should just create SQLConf and set values appropriately).

Linear Supertypes
Product, Equals, SQLConf, Logging, Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. SimpleCatalystConf
  2. Product
  3. Equals
  4. SQLConf
  5. Logging
  6. Serializable
  7. Serializable
  8. AnyRef
  9. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SimpleCatalystConf(caseSensitiveAnalysis: Boolean, orderByOrdinal: Boolean = true, groupByOrdinal: Boolean = true, optimizerMaxIterations: Int = 100, optimizerInSetConversionThreshold: Int = 10, maxCaseBranchesForCodegen: Int = 20, runSQLonFile: Boolean = true, crossJoinEnabled: Boolean = false, warehousePath: String = "/user/hive/warehouse")

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

    Definition Classes
    SQLConf
  7. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  8. def autoBroadcastJoinThreshold: Long

    Definition Classes
    SQLConf
  9. def broadcastTimeout: Int

    Definition Classes
    SQLConf
  10. def bucketingEnabled: Boolean

    Definition Classes
    SQLConf
  11. val caseSensitiveAnalysis: Boolean

    Definition Classes
    SimpleCatalystConfSQLConf
  12. def caseSensitiveInferenceMode: internal.SQLConf.HiveCaseSensitiveInferenceMode.Value

    Definition Classes
    SQLConf
  13. def checkpointLocation: Option[String]

    Definition Classes
    SQLConf
  14. def clear(): Unit

    Definition Classes
    SQLConf
  15. def clone(): AnyRef

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

    Definition Classes
    SQLConf
  17. def columnNameOfCorruptRecord: String

    Definition Classes
    SQLConf
  18. def contains(key: String): Boolean

    Return whether a given key is set in this SQLConf.

    Return whether a given key is set in this SQLConf.

    Definition Classes
    SQLConf
  19. def convertCTAS: Boolean

    Definition Classes
    SQLConf
  20. val crossJoinEnabled: Boolean

    Definition Classes
    SimpleCatalystConfSQLConf
  21. def dataFramePivotMaxValues: Int

    Definition Classes
    SQLConf
  22. def dataFrameRetainGroupColumns: Boolean

    Definition Classes
    SQLConf
  23. def dataFrameSelfJoinAutoResolveAmbiguity: Boolean

    Definition Classes
    SQLConf
  24. def defaultDataSourceName: String

    Definition Classes
    SQLConf
  25. def defaultSizeInBytes: Long

    Definition Classes
    SQLConf
  26. def enableRadixSort: Boolean

    Definition Classes
    SQLConf
  27. def enableTwoLevelAggMap: Boolean

    Definition Classes
    SQLConf
  28. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  29. def exchangeReuseEnabled: Boolean

    Definition Classes
    SQLConf
  30. def fallBackToHdfsForStatsEnabled: Boolean

    Definition Classes
    SQLConf
  31. def fileCommitProtocolClass: String

    Definition Classes
    SQLConf
  32. def fileSinkLogCleanupDelay: Long

    Definition Classes
    SQLConf
  33. def fileSinkLogCompactInterval: Int

    Definition Classes
    SQLConf
  34. def fileSinkLogDeletion: Boolean

    Definition Classes
    SQLConf
  35. def fileSourceLogCleanupDelay: Long

    Definition Classes
    SQLConf
  36. def fileSourceLogCompactInterval: Int

    Definition Classes
    SQLConf
  37. def fileSourceLogDeletion: Boolean

    Definition Classes
    SQLConf
  38. def filesMaxPartitionBytes: Long

    Definition Classes
    SQLConf
  39. def filesOpenCostInBytes: Long

    Definition Classes
    SQLConf
  40. def filesourcePartitionFileCacheSize: Long

    Definition Classes
    SQLConf
  41. def finalize(): Unit

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

    Definition Classes
    SQLConf
  43. def getAllConfs: Map[String, String]

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

    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.

    Definition Classes
    SQLConf
  44. def getAllDefinedConfs: Seq[(String, String, String)]

    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.

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

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

    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.

    Definition Classes
    SQLConf
  47. def getConf[T](entry: ConfigEntry[T]): T

    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.

    Definition Classes
    SQLConf
  48. def getConf[T](entry: ConfigEntry[T], defaultValue: T): T

    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.

    Definition Classes
    SQLConf
  49. def getConfString(key: String, defaultValue: String): String

    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.

    Definition Classes
    SQLConf
  50. def getConfString(key: String): String

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

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

    Definition Classes
    SQLConf
    Annotations
    @throws( "if key is not set" )
  51. val groupByOrdinal: Boolean

    Definition Classes
    SimpleCatalystConfSQLConf
  52. def ignoreCorruptFiles: Boolean

    Definition Classes
    SQLConf
  53. def inMemoryPartitionPruning: Boolean

    Definition Classes
    SQLConf
  54. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

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

    Definition Classes
    Any
  56. def isParquetBinaryAsString: Boolean

    Definition Classes
    SQLConf
  57. def isParquetINT96AsTimestamp: Boolean

    Definition Classes
    SQLConf
  58. def isParquetSchemaMergingEnabled: Boolean

    Definition Classes
    SQLConf
  59. def isParquetSchemaRespectSummaries: Boolean

    Definition Classes
    SQLConf
  60. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  61. def isUnsupportedOperationCheckEnabled: Boolean

    Definition Classes
    SQLConf
  62. def limitScaleUpFactor: Int

    Definition Classes
    SQLConf
  63. def log: Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  70. def logName: String

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  75. def manageFilesourcePartitions: Boolean

    Definition Classes
    SQLConf
  76. val maxCaseBranchesForCodegen: Int

    Definition Classes
    SimpleCatalystConfSQLConf
  77. def metastorePartitionPruning: Boolean

    Definition Classes
    SQLConf
  78. def minBatchesToRetain: Int

    Definition Classes
    SQLConf
  79. def minNumPostShufflePartitions: Int

    Definition Classes
    SQLConf
  80. def ndvMaxError: Double

    Definition Classes
    SQLConf
  81. final def ne(arg0: AnyRef): Boolean

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

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

    Definition Classes
    AnyRef
  84. def numShufflePartitions: Int

    Definition Classes
    SQLConf
  85. val optimizerInSetConversionThreshold: Int

    Definition Classes
    SimpleCatalystConfSQLConf
  86. val optimizerMaxIterations: Int

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

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

    Definition Classes
    SimpleCatalystConfSQLConf
  87. def optimizerMetadataOnly: Boolean

    Definition Classes
    SQLConf
  88. def orcFilterPushDown: Boolean

    Definition Classes
    SQLConf
  89. val orderByOrdinal: Boolean

    Definition Classes
    SimpleCatalystConfSQLConf
  90. def parallelPartitionDiscoveryParallelism: Int

    Definition Classes
    SQLConf
  91. def parallelPartitionDiscoveryThreshold: Int

    Definition Classes
    SQLConf
  92. def parquetCacheMetadata: Boolean

    Definition Classes
    SQLConf
  93. def parquetCompressionCodec: String

    Definition Classes
    SQLConf
  94. def parquetFilterPushDown: Boolean

    Definition Classes
    SQLConf
  95. def parquetOutputCommitterClass: String

    Definition Classes
    SQLConf
  96. def parquetVectorizedReaderEnabled: Boolean

    Definition Classes
    SQLConf
  97. def partitionColumnTypeInferenceEnabled: Boolean

    Definition Classes
    SQLConf
  98. def preferSortMergeJoin: Boolean

    Definition Classes
    SQLConf
  99. def resolver: (String, String) ⇒ Boolean

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

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

    Definition Classes
    SQLConf
  100. val runSQLonFile: Boolean

    Definition Classes
    SimpleCatalystConfSQLConf
  101. def setConf[T](entry: ConfigEntry[T], value: T): Unit

    Set the given Spark SQL configuration property.

    Set the given Spark SQL configuration property.

    Definition Classes
    SQLConf
  102. def setConf(props: Properties): Unit

    Set Spark SQL configuration properties.

    Set Spark SQL configuration properties.

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

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

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

    Definition Classes
    SQLConf
  104. val settings: Map[String, String]

    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]
    Definition Classes
    SQLConf
  105. def stateStoreMinDeltasForSnapshot: Int

    Definition Classes
    SQLConf
  106. def streamingFileCommitProtocolClass: String

    Definition Classes
    SQLConf
  107. def streamingMetricsEnabled: Boolean

    Definition Classes
    SQLConf
  108. def streamingNoDataProgressEventInterval: Long

    Definition Classes
    SQLConf
  109. def streamingPollingDelay: Long

    Definition Classes
    SQLConf
  110. def streamingProgressRetention: Int

    Definition Classes
    SQLConf
  111. def streamingSchemaInference: Boolean

    Definition Classes
    SQLConf
  112. def subexpressionEliminationEnabled: Boolean

    Definition Classes
    SQLConf
  113. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  114. def targetPostShuffleInputSize: Long

    Definition Classes
    SQLConf
  115. def unsetConf(entry: ConfigEntry[_]): Unit

    Definition Classes
    SQLConf
  116. def unsetConf(key: String): Unit

    Definition Classes
    SQLConf
  117. def useCompression: Boolean

    Definition Classes
    SQLConf
  118. def variableSubstituteDepth: Int

    Definition Classes
    SQLConf
  119. def variableSubstituteEnabled: Boolean

    Definition Classes
    SQLConf
  120. def verifyPartitionPath: Boolean

    Definition Classes
    SQLConf
  121. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  124. val warehousePath: String

    Definition Classes
    SimpleCatalystConfSQLConf
  125. def wholeStageEnabled: Boolean

    Definition Classes
    SQLConf
  126. def wholeStageFallback: Boolean

    Definition Classes
    SQLConf
  127. def wholeStageMaxNumFields: Int

    Definition Classes
    SQLConf
  128. def writeLegacyParquetFormat: Boolean

    Definition Classes
    SQLConf

Inherited from Product

Inherited from Equals

Inherited from SQLConf

Inherited from Logging

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped