public class InMemoryRelation
extends org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
implements org.apache.spark.sql.catalyst.analysis.MultiInstanceRelation, scala.Product, scala.Serializable
Constructor and Description |
---|
InMemoryRelation(scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output,
boolean useCompression,
int batchSize,
StorageLevel storageLevel,
org.apache.spark.sql.execution.SparkPlan child,
scala.Option<String> tableName,
RDD<CachedBatch> _cachedColumnBuffers,
org.apache.spark.sql.catalyst.plans.logical.Statistics _statistics) |
Modifier and Type | Method and Description |
---|---|
static InMemoryRelation |
apply(boolean useCompression,
int batchSize,
StorageLevel storageLevel,
org.apache.spark.sql.execution.SparkPlan child,
scala.Option<String> tableName) |
int |
batchSize() |
RDD<CachedBatch> |
cachedColumnBuffers() |
org.apache.spark.sql.execution.SparkPlan |
child() |
scala.collection.Seq<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan> |
children() |
InMemoryRelation |
newInstance() |
scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> |
output() |
PartitionStatistics |
partitionStatistics() |
void |
recache() |
org.apache.spark.sql.catalyst.plans.logical.Statistics |
statistics() |
StorageLevel |
storageLevel() |
scala.Option<String> |
tableName() |
boolean |
useCompression() |
InMemoryRelation |
withOutput(scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> newOutput) |
childrenResolved, cleanArgs, isTraceEnabled, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning, org$apache$spark$Logging$$log__$eq, org$apache$spark$Logging$$log_, org$apache$spark$sql$catalyst$plans$logical$LogicalPlan$$resolveAsColumn, org$apache$spark$sql$catalyst$plans$logical$LogicalPlan$$resolveAsTableColumn, resolve, resolve, resolve$default$3, resolveChildren, resolveChildren$default$3, resolved, resolveGetField, sameResult, statePrefix
expressions, inputSet, missingInput, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionDown$1, org$apache$spark$sql$catalyst$plans$QueryPlan$$transformExpressionUp$1, outputSet, printSchema, references, schema, schemaString, simpleString, transformAllExpressions, transformExpressions, transformExpressionsDown, transformExpressionsUp
apply, argString, asCode, collect, fastEquals, flatMap, foreach, foreachUp, generateTreeString, getNodeNumbered, makeCopy, map, mapChildren, nodeName, numberedTreeString, origin, stringArgs, toString, transform, transformChildrenDown, transformChildrenUp, transformDown, transformUp, treeString, withNewChildren
productArity, productElement, productIterator, productPrefix
initializeIfNecessary, initializeLogging, log_
public InMemoryRelation(scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output, boolean useCompression, int batchSize, StorageLevel storageLevel, org.apache.spark.sql.execution.SparkPlan child, scala.Option<String> tableName, RDD<CachedBatch> _cachedColumnBuffers, org.apache.spark.sql.catalyst.plans.logical.Statistics _statistics)
public static InMemoryRelation apply(boolean useCompression, int batchSize, StorageLevel storageLevel, org.apache.spark.sql.execution.SparkPlan child, scala.Option<String> tableName)
public scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> output()
output
in class org.apache.spark.sql.catalyst.plans.QueryPlan<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>
public boolean useCompression()
public int batchSize()
public StorageLevel storageLevel()
public org.apache.spark.sql.execution.SparkPlan child()
public scala.Option<String> tableName()
public PartitionStatistics partitionStatistics()
public org.apache.spark.sql.catalyst.plans.logical.Statistics statistics()
statistics
in class org.apache.spark.sql.catalyst.plans.logical.LogicalPlan
public void recache()
public InMemoryRelation withOutput(scala.collection.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> newOutput)
public scala.collection.Seq<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan> children()
children
in class org.apache.spark.sql.catalyst.trees.TreeNode<org.apache.spark.sql.catalyst.plans.logical.LogicalPlan>
public InMemoryRelation newInstance()
newInstance
in interface org.apache.spark.sql.catalyst.analysis.MultiInstanceRelation
public RDD<CachedBatch> cachedColumnBuffers()