public interface ColumnStats
extends scala.Serializable
NOTE: we intentionally avoid using Ordering[T] to compare values here because Ordering[T]
brings significant performance penalty.
| Modifier and Type | Method and Description |
|---|---|
org.apache.spark.sql.catalyst.expressions.Row |
collectedStatistics()
Column statistics represented as a single row, currently including closed lower bound, closed
upper bound and null count.
|
int |
count() |
void |
gatherStats(org.apache.spark.sql.catalyst.expressions.Row row,
int ordinal)
Gathers statistics information from
row(ordinal). |
int |
nullCount() |
long |
sizeInBytes() |
int count()
int nullCount()
long sizeInBytes()
void gatherStats(org.apache.spark.sql.catalyst.expressions.Row row,
int ordinal)
row(ordinal).org.apache.spark.sql.catalyst.expressions.Row collectedStatistics()