Packages

c

org.apache.spark.sql.expressions

MutableAggregationBuffer

abstract class MutableAggregationBuffer extends Row

A Row representing a mutable aggregation buffer.

This is not meant to be extended outside of Spark.

Annotations
@Stable()
Since

1.5.0

Linear Supertypes
Row, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. MutableAggregationBuffer
  2. Row
  3. Serializable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new MutableAggregationBuffer()

Abstract Value Members

  1. abstract def copy(): Row
    Definition Classes
    Row
  2. abstract def get(i: Int): Any
    Definition Classes
    Row
  3. abstract def length: Int
    Definition Classes
    Row
  4. abstract def update(i: Int, value: Any): Unit

    Update the ith value of this buffer.

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def anyNull: Boolean
    Definition Classes
    Row
  5. def apply(i: Int): Any
    Definition Classes
    Row
  6. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native()
  8. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  9. def equals(o: Any): Boolean
    Definition Classes
    Row → AnyRef → Any
  10. def fieldIndex(name: String): Int
    Definition Classes
    Row
  11. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable])
  12. def getAs[T](fieldName: String): T
    Definition Classes
    Row
  13. def getAs[T](i: Int): T
    Definition Classes
    Row
  14. def getBoolean(i: Int): Boolean
    Definition Classes
    Row
  15. def getByte(i: Int): Byte
    Definition Classes
    Row
  16. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  17. def getDate(i: Int): Date
    Definition Classes
    Row
  18. def getDecimal(i: Int): BigDecimal
    Definition Classes
    Row
  19. def getDouble(i: Int): Double
    Definition Classes
    Row
  20. def getFloat(i: Int): Float
    Definition Classes
    Row
  21. def getInstant(i: Int): Instant
    Definition Classes
    Row
  22. def getInt(i: Int): Int
    Definition Classes
    Row
  23. def getJavaMap[K, V](i: Int): Map[K, V]
    Definition Classes
    Row
  24. def getList[T](i: Int): List[T]
    Definition Classes
    Row
  25. def getLocalDate(i: Int): LocalDate
    Definition Classes
    Row
  26. def getLong(i: Int): Long
    Definition Classes
    Row
  27. def getMap[K, V](i: Int): Map[K, V]
    Definition Classes
    Row
  28. def getSeq[T](i: Int): Seq[T]
    Definition Classes
    Row
  29. def getShort(i: Int): Short
    Definition Classes
    Row
  30. def getString(i: Int): String
    Definition Classes
    Row
  31. def getStruct(i: Int): Row
    Definition Classes
    Row
  32. def getTimestamp(i: Int): Timestamp
    Definition Classes
    Row
  33. def getValuesMap[T](fieldNames: Seq[String]): Map[String, T]
    Definition Classes
    Row
  34. def hashCode(): Int
    Definition Classes
    Row → AnyRef → Any
  35. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  36. def isNullAt(i: Int): Boolean
    Definition Classes
    Row
  37. def json: String
    Definition Classes
    Row
    Annotations
    @Unstable()
  38. def mkString(start: String, sep: String, end: String): String
    Definition Classes
    Row
  39. def mkString(sep: String): String
    Definition Classes
    Row
  40. def mkString: String
    Definition Classes
    Row
  41. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  42. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  43. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  44. def prettyJson: String
    Definition Classes
    Row
    Annotations
    @Unstable()
  45. def schema: StructType
    Definition Classes
    Row
  46. def size: Int
    Definition Classes
    Row
  47. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  48. def toSeq: Seq[Any]
    Definition Classes
    Row
  49. def toString(): String
    Definition Classes
    Row → AnyRef → Any
  50. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  51. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  52. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()

Inherited from Row

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped