abstract class MutableAggregationBuffer extends Row
A Row representing a mutable aggregation buffer.
This is not meant to be extended outside of Spark.
- Annotations
- @Stable()
- Source
- udaf.scala
- Since
- 1.5.0 
- Alphabetic
- By Inheritance
- MutableAggregationBuffer
- Row
- Serializable
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Instance Constructors
-  new MutableAggregationBuffer()
Abstract Value Members
-   abstract  def copy(): RowMake a copy of the current Row object. 
-   abstract  def get(i: Int): AnyReturns the value at position i. Returns the value at position i. If the value is null, null is returned. The following is a mapping between Spark SQL types and return types: BooleanType -> java.lang.Boolean ByteType -> java.lang.Byte ShortType -> java.lang.Short IntegerType -> java.lang.Integer LongType -> java.lang.Long FloatType -> java.lang.Float DoubleType -> java.lang.Double StringType -> String DecimalType -> java.math.BigDecimal DateType -> java.sql.Date if spark.sql.datetime.java8API.enabled is false DateType -> java.time.LocalDate if spark.sql.datetime.java8API.enabled is true TimestampType -> java.sql.Timestamp if spark.sql.datetime.java8API.enabled is false TimestampType -> java.time.Instant if spark.sql.datetime.java8API.enabled is true BinaryType -> byte array ArrayType -> scala.collection.Seq (use getList for java.util.List) MapType -> scala.collection.Map (use getJavaMap for java.util.Map) StructType -> org.apache.spark.sql.Row - Definition Classes
- Row
 
-   abstract  def length: IntNumber of elements in the Row. Number of elements in the Row. - Definition Classes
- Row
 
-   abstract  def update(i: Int, value: Any): UnitUpdate the ith value of this buffer. 
Concrete Value Members
-   final  def !=(arg0: Any): Boolean- Definition Classes
- AnyRef → Any
 
-   final  def ##: Int- Definition Classes
- AnyRef → Any
 
-   final  def ==(arg0: Any): Boolean- Definition Classes
- AnyRef → Any
 
-    def anyNull: BooleanReturns true if there are any NULL values in this row. Returns true if there are any NULL values in this row. - Definition Classes
- Row
 
-    def apply(i: Int): AnyReturns the value at position i. Returns the value at position i. If the value is null, null is returned. The following is a mapping between Spark SQL types and return types: BooleanType -> java.lang.Boolean ByteType -> java.lang.Byte ShortType -> java.lang.Short IntegerType -> java.lang.Integer LongType -> java.lang.Long FloatType -> java.lang.Float DoubleType -> java.lang.Double StringType -> String DecimalType -> java.math.BigDecimal DateType -> java.sql.Date if spark.sql.datetime.java8API.enabled is false DateType -> java.time.LocalDate if spark.sql.datetime.java8API.enabled is true TimestampType -> java.sql.Timestamp if spark.sql.datetime.java8API.enabled is false TimestampType -> java.time.Instant if spark.sql.datetime.java8API.enabled is true BinaryType -> byte array ArrayType -> scala.collection.Seq (use getList for java.util.List) MapType -> scala.collection.Map (use getJavaMap for java.util.Map) StructType -> org.apache.spark.sql.Row - Definition Classes
- Row
 
-   final  def asInstanceOf[T0]: T0- Definition Classes
- Any
 
-    def clone(): AnyRef- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
 
-   final  def eq(arg0: AnyRef): Boolean- Definition Classes
- AnyRef
 
-    def equals(o: Any): Boolean- Definition Classes
- Row → AnyRef → Any
 
-    def fieldIndex(name: String): IntReturns the index of a given field name. Returns the index of a given field name. - Definition Classes
- Row
- Exceptions thrown
- IllegalArgumentExceptionwhen a field- namedoes not exist.- UnsupportedOperationExceptionwhen schema is not defined.
 
-    def getAs[T](fieldName: String): TReturns the value of a given fieldName. Returns the value of a given fieldName. For primitive types if value is null it returns 'zero value' specific for primitive i.e. 0 for Int - use isNullAt to ensure that value is not null - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- IllegalArgumentExceptionwhen fieldName do not exist.- UnsupportedOperationExceptionwhen schema is not defined.
 
-    def getAs[T](i: Int): TReturns the value at position i. Returns the value at position i. For primitive types if value is null it returns 'zero value' specific for primitive i.e. 0 for Int - use isNullAt to ensure that value is not null - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getBoolean(i: Int): BooleanReturns the value at position i as a primitive boolean. Returns the value at position i as a primitive boolean. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- org.apache.spark.SparkRuntimeExceptionwhen value is null.
 
-    def getByte(i: Int): ByteReturns the value at position i as a primitive byte. Returns the value at position i as a primitive byte. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- org.apache.spark.SparkRuntimeExceptionwhen value is null.
 
-   final  def getClass(): Class[_ <: AnyRef]- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
 
-    def getDate(i: Int): DateReturns the value at position i of date type as java.sql.Date. Returns the value at position i of date type as java.sql.Date. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getDecimal(i: Int): BigDecimalReturns the value at position i of decimal type as java.math.BigDecimal. Returns the value at position i of decimal type as java.math.BigDecimal. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getDouble(i: Int): DoubleReturns the value at position i as a primitive double. Returns the value at position i as a primitive double. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- org.apache.spark.SparkRuntimeExceptionwhen value is null.
 
-    def getFloat(i: Int): FloatReturns the value at position i as a primitive float. Returns the value at position i as a primitive float. Throws an exception if the type mismatches or if the value is null. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- org.apache.spark.SparkRuntimeExceptionwhen value is null.
 
-    def getInstant(i: Int): InstantReturns the value at position i of date type as java.time.Instant. Returns the value at position i of date type as java.time.Instant. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getInt(i: Int): IntReturns the value at position i as a primitive int. Returns the value at position i as a primitive int. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- org.apache.spark.SparkRuntimeExceptionwhen value is null.
 
-    def getJavaMap[K, V](i: Int): Map[K, V]Returns the value at position i of array type as a java.util.Map.Returns the value at position i of array type as a java.util.Map.- Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getList[T](i: Int): List[T]Returns the value at position i of array type as java.util.List.Returns the value at position i of array type as java.util.List.- Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getLocalDate(i: Int): LocalDateReturns the value at position i of date type as java.time.LocalDate. Returns the value at position i of date type as java.time.LocalDate. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getLong(i: Int): LongReturns the value at position i as a primitive long. Returns the value at position i as a primitive long. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- org.apache.spark.SparkRuntimeExceptionwhen value is null.
 
-    def getMap[K, V](i: Int): Map[K, V]Returns the value at position i of map type as a Scala Map. Returns the value at position i of map type as a Scala Map. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getSeq[T](i: Int): Seq[T]Returns the value at position i of array type as a Scala Seq. Returns the value at position i of array type as a Scala Seq. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getShort(i: Int): ShortReturns the value at position i as a primitive short. Returns the value at position i as a primitive short. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- org.apache.spark.SparkRuntimeExceptionwhen value is null.
 
-    def getString(i: Int): StringReturns the value at position i as a String object. Returns the value at position i as a String object. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getStruct(i: Int): RowReturns the value at position i of struct type as a Row object. 
-    def getTimestamp(i: Int): TimestampReturns the value at position i of date type as java.sql.Timestamp. Returns the value at position i of date type as java.sql.Timestamp. - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.
 
-    def getValuesMap[T](fieldNames: Seq[String]): Map[String, T]Returns a Map consisting of names and values for the requested fieldNames For primitive types if value is null it returns 'zero value' specific for primitive i.e. Returns a Map consisting of names and values for the requested fieldNames For primitive types if value is null it returns 'zero value' specific for primitive i.e. 0 for Int - use isNullAt to ensure that value is not null - Definition Classes
- Row
- Exceptions thrown
- ClassCastExceptionwhen data type does not match.- IllegalArgumentExceptionwhen fieldName do not exist.- UnsupportedOperationExceptionwhen schema is not defined.
 
-    def hashCode(): Int- Definition Classes
- Row → AnyRef → Any
 
-   final  def isInstanceOf[T0]: Boolean- Definition Classes
- Any
 
-    def isNullAt(i: Int): BooleanChecks whether the value at position i is null. Checks whether the value at position i is null. - Definition Classes
- Row
 
-    def json: StringThe compact JSON representation of this row. The compact JSON representation of this row. - Definition Classes
- Row
- Annotations
- @Unstable()
- Since
- 3.0 
 
-    def mkString(start: String, sep: String, end: String): StringDisplays all elements of this traversable or iterator in a string using start, end, and separator strings. Displays all elements of this traversable or iterator in a string using start, end, and separator strings. - Definition Classes
- Row
 
-    def mkString(sep: String): StringDisplays all elements of this sequence in a string using a separator string. Displays all elements of this sequence in a string using a separator string. - Definition Classes
- Row
 
-    def mkString: StringDisplays all elements of this sequence in a string (without a separator). Displays all elements of this sequence in a string (without a separator). - Definition Classes
- Row
 
-   final  def ne(arg0: AnyRef): Boolean- Definition Classes
- AnyRef
 
-   final  def notify(): Unit- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
 
-   final  def notifyAll(): Unit- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
 
-    def prettyJson: StringThe pretty (i.e. The pretty (i.e. indented) JSON representation of this row. - Definition Classes
- Row
- Annotations
- @Unstable()
- Since
- 3.0 
 
-    def schema: StructTypeSchema for the row. Schema for the row. - Definition Classes
- Row
 
-    def size: IntNumber of elements in the Row. Number of elements in the Row. - Definition Classes
- Row
 
-   final  def synchronized[T0](arg0: => T0): T0- Definition Classes
- AnyRef
 
-    def toSeq: Seq[Any]Return a Scala Seq representing the row. Return a Scala Seq representing the row. Elements are placed in the same order in the Seq. - Definition Classes
- Row
 
-    def toString(): String- Definition Classes
- Row → AnyRef → Any
 
-   final  def wait(arg0: Long, arg1: Int): Unit- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
 
-   final  def wait(arg0: Long): Unit- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
 
-   final  def wait(): Unit- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
 
Deprecated Value Members
-    def finalize(): Unit- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
- (Since version 9)