Spark 3.5.5 ScalaDoc - org.apache.spark.sql.Row (original) (raw)

trait Row extends Serializable

Ordering

  1. Alphabetic
  2. By Inheritance

Inherited

  1. Row

  2. Serializable

  3. Serializable

  4. AnyRef

  5. Any

  6. Hide All

  7. Show All

Abstract Value Members

  1. abstract def copy(): Row
  2. abstract def get(i: Int): Any
  3. abstract def length: Int

Concrete Value Members

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

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped