public class SparkSessionExtensions
extends Object
SparkSession
. We make NO guarantee about the stability
regarding binary compatibility and source compatibility of methods here.
This current provides the following extension points:
The extensions can be used by calling withExtension on the SparkSession.Builder
, for
example:
SparkSession.builder()
.master("...")
.conf("...", true)
.withExtensions { extensions =>
extensions.injectResolutionRule { session =>
...
}
extensions.injectParser { (session, parser) =>
...
}
}
.getOrCreate()
Note that none of the injected builders should assume that the SparkSession
is fully
initialized and should not touch the session's internals (e.g. the SessionState).
Constructor and Description |
---|
SparkSessionExtensions() |
Modifier and Type | Method and Description |
---|---|
void |
injectCheckRule(scala.Function1<SparkSession,scala.Function1<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan,scala.runtime.BoxedUnit>> builder)
Inject an check analysis
Rule builder into the SparkSession . |
void |
injectOptimizerRule(scala.Function1<SparkSession,org.apache.spark.sql.catalyst.rules.Rule<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>> builder)
Inject an optimizer
Rule builder into the SparkSession . |
void |
injectParser(scala.Function2<SparkSession,org.apache.spark.sql.catalyst.parser.ParserInterface,org.apache.spark.sql.catalyst.parser.ParserInterface> builder)
Inject a custom parser into the
SparkSession . |
void |
injectPlannerStrategy(scala.Function1<SparkSession,org.apache.spark.sql.execution.SparkStrategy> builder)
Inject a planner
Strategy builder into the SparkSession . |
void |
injectPostHocResolutionRule(scala.Function1<SparkSession,org.apache.spark.sql.catalyst.rules.Rule<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>> builder)
Inject an analyzer
Rule builder into the SparkSession . |
void |
injectResolutionRule(scala.Function1<SparkSession,org.apache.spark.sql.catalyst.rules.Rule<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>> builder)
Inject an analyzer resolution
Rule builder into the SparkSession . |
public void injectCheckRule(scala.Function1<SparkSession,scala.Function1<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan,scala.runtime.BoxedUnit>> builder)
Rule
builder into the SparkSession
. The injected rules will
be executed after the analysis phase. A check analysis rule is used to detect problems with a
LogicalPlan and should throw an exception when a problem is found.builder
- (undocumented)public void injectOptimizerRule(scala.Function1<SparkSession,org.apache.spark.sql.catalyst.rules.Rule<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>> builder)
Rule
builder into the SparkSession
. The injected rules will be
executed during the operator optimization batch. An optimizer rule is used to improve the
quality of an analyzed logical plan; these rules should never modify the result of the
LogicalPlan.builder
- (undocumented)public void injectParser(scala.Function2<SparkSession,org.apache.spark.sql.catalyst.parser.ParserInterface,org.apache.spark.sql.catalyst.parser.ParserInterface> builder)
SparkSession
. Note that the builder is passed a session
and an initial parser. The latter allows for a user to create a partial parser and to delegate
to the underlying parser for completeness. If a user injects more parsers, then the parsers
are stacked on top of each other.builder
- (undocumented)public void injectPlannerStrategy(scala.Function1<SparkSession,org.apache.spark.sql.execution.SparkStrategy> builder)
Strategy
builder into the SparkSession
. The injected strategy will
be used to convert a LogicalPlan
into a executable
SparkPlan
.builder
- (undocumented)public void injectPostHocResolutionRule(scala.Function1<SparkSession,org.apache.spark.sql.catalyst.rules.Rule<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>> builder)
Rule
builder into the SparkSession
. These analyzer
rules will be executed after resolution.builder
- (undocumented)public void injectResolutionRule(scala.Function1<SparkSession,org.apache.spark.sql.catalyst.rules.Rule<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>> builder)
Rule
builder into the SparkSession
. These analyzer
rules will be executed as part of the resolution phase of analysis.builder
- (undocumented)