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

Inherited from Row

Inherited from GettableData

Inherited from GettableByIndexData

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped