final class CassandraSQLRow extends GettableData with Row with Serializable

Linear Supertypes
Row, GettableData, GettableByIndexData, Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. CassandraSQLRow
  2. Row
  3. GettableData
  4. GettableByIndexData
  5. Serializable
  6. Serializable
  7. AnyRef
  8. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new CassandraSQLRow(metaData: CassandraRowMetadata, columnValues: IndexedSeq[AnyRef])

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): AnyRef
    Definition Classes
    CassandraSQLRow → Row
  6. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native() @HotSpotIntrinsicCandidate()
  8. val columnValues: IndexedSeq[AnyRef]
    Definition Classes
    CassandraSQLRow → GettableByIndexData
  9. def contains(name: String): Boolean
    Definition Classes
    GettableData
  10. def copy(): CassandraSQLRow
    Definition Classes
    CassandraSQLRow → Row
  11. def dataAsString: String
    Definition Classes
    GettableData → GettableByIndexData
  12. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  13. def equals(o: Any): Boolean
    Definition Classes
    Row → AnyRef → Any
  14. def fieldIndex(name: String): Int
    Definition Classes
    Row
  15. def fieldNames: CassandraRowMetadata
    Attributes
    protected
  16. def get(i: Int): Any
    Definition Classes
    CassandraSQLRow → Row
  17. def getAs[T](fieldName: String): T
    Definition Classes
    Row
  18. def getAs[T](i: Int): T
    Definition Classes
    Row
  19. def getBoolean(i: Int): Boolean
    Definition Classes
    CassandraSQLRow → Row
  20. def getByte(i: Int): Byte
    Definition Classes
    CassandraSQLRow → Row
  21. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  22. def getDate(i: Int): Date
    Definition Classes
    Row
  23. def getDecimal(i: Int): BigDecimal
    Definition Classes
    Row
  24. def getDouble(i: Int): Double
    Definition Classes
    CassandraSQLRow → Row
  25. def getFloat(i: Int): Float
    Definition Classes
    CassandraSQLRow → Row
  26. def getInstant(i: Int): Instant
    Definition Classes
    Row
  27. def getInt(i: Int): Int
    Definition Classes
    CassandraSQLRow → Row
  28. def getJavaMap[K, V](i: Int): Map[K, V]
    Definition Classes
    Row
  29. def getList[T](i: Int): List[T]
    Definition Classes
    Row
  30. def getLocalDate(i: Int): LocalDate
    Definition Classes
    Row
  31. def getLong(i: Int): Long
    Definition Classes
    CassandraSQLRow → Row
  32. def getMap[K, V](i: Int): Map[K, V]
    Definition Classes
    Row
  33. def getRaw(name: String): AnyRef
    Definition Classes
    GettableData
  34. def getRaw(index: Int): AnyRef
    Definition Classes
    GettableByIndexData
  35. def getRawCql(name: String): AnyRef
    Definition Classes
    GettableData
  36. def getSeq[T](i: Int): Seq[T]
    Definition Classes
    Row
  37. def getShort(i: Int): Short
    Definition Classes
    CassandraSQLRow → Row
  38. def getString(i: Int): String
    Definition Classes
    CassandraSQLRow → Row
  39. def getStruct(i: Int): Row
    Definition Classes
    Row
  40. def getTimestamp(i: Int): Timestamp
    Definition Classes
    Row
  41. def getValuesMap[T](fieldNames: Seq[String]): Map[String, T]
    Definition Classes
    Row
  42. def hashCode(): Int
    Definition Classes
    Row → AnyRef → Any
  43. def indexOf(name: String): Int
    Definition Classes
    GettableData
  44. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  45. def isNullAt(i: Int): Boolean
    Definition Classes
    CassandraSQLRow → Row → GettableByIndexData
  46. def isNullAt(name: String): Boolean
    Definition Classes
    GettableData
  47. def json: String
    Definition Classes
    Row
    Annotations
    @Unstable()
  48. def length: Int
    Definition Classes
    GettableByIndexData
  49. val metaData: CassandraRowMetadata
    Definition Classes
    CassandraSQLRow → GettableData
  50. def mkString(start: String, sep: String, end: String): String
    Definition Classes
    Row
  51. def mkString(sep: String): String
    Definition Classes
    Row
  52. def mkString: String
    Definition Classes
    Row
  53. def nameOf(index: Int): String
    Definition Classes
    GettableData
  54. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  55. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  56. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  57. def prettyJson: String
    Definition Classes
    Row
    Annotations
    @Unstable()
  58. def schema: StructType
    Definition Classes
    Row
  59. def size: Int
    Definition Classes
    CassandraSQLRow → Row → GettableByIndexData
  60. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  61. def toSeq: Seq[Any]
    Definition Classes
    CassandraSQLRow → Row
  62. def toString(): String
    Definition Classes
    Row → AnyRef → Any
  63. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  64. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  65. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] ) @Deprecated @deprecated
    Deprecated

    (Since version ) see corresponding Javadoc for more information.

Inherited from Row

Inherited from GettableData

Inherited from GettableByIndexData

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped