Class and Description |
---|
org.apache.spark.ml.feature.ChiSqSelector
use UnivariateFeatureSelector instead. Since 3.1.1.
|
org.apache.spark.scheduler.SparkListenerExecutorBlacklisted
use SparkListenerExecutorExcluded instead. Since 3.1.0.
|
org.apache.spark.scheduler.SparkListenerExecutorBlacklistedForStage
use SparkListenerExecutorExcludedForStage instead. Since 3.1.0.
|
org.apache.spark.scheduler.SparkListenerExecutorUnblacklisted
use SparkListenerExecutorUnexcluded instead. Since 3.1.0.
|
org.apache.spark.scheduler.SparkListenerNodeBlacklisted
use SparkListenerNodeExcluded instead. Since 3.1.0.
|
org.apache.spark.scheduler.SparkListenerNodeBlacklistedForStage
use SparkListenerNodeExcludedForStage instead. Since 3.1.0.
|
org.apache.spark.scheduler.SparkListenerNodeUnblacklisted
use SparkListenerNodeUnexcluded instead. Since 3.1.0.
|
org.apache.spark.sql.expressions.javalang.typed
As of release 3.0.0, please use the untyped builtin aggregate functions.
|
org.apache.spark.sql.expressions.scalalang.typed
please use untyped builtin aggregate functions. Since 3.0.0.
|
org.apache.spark.sql.expressions.UserDefinedAggregateFunction
UserDefinedAggregateFunction is deprecated.
Aggregator[IN, BUF, OUT] should now be registered as a UDF via the functions.udaf(agg) method.
|
Field and Description |
---|
org.apache.spark.launcher.SparkLauncher.DEPRECATED_CHILD_CONNECTION_TIMEOUT
use `CHILD_CONNECTION_TIMEOUT`
|
Constructor and Description |
---|
org.apache.spark.sql.SQLContext(JavaSparkContext)
Use SparkSession.builder instead. Since 2.0.0.
|
org.apache.spark.sql.SQLContext(SparkContext)
Use SparkSession.builder instead. Since 2.0.0.
|