org.apache.spark.sql.rowtable

RowFormatRelation

class RowFormatRelation extends JDBCMutableRelation with PartitionedDataSourceScan with RowPutRelation

A LogicalPlan implementation for an Snappy row table whose contents are retrieved using a JDBC URL or DataSource.

Linear Supertypes
RowPutRelation, PartitionedDataSourceScan, JDBCMutableRelation, Logging, IndexableRelation, DestroyRelation, DeletableRelation, UpdatableRelation, RowInsertableRelation, SingleRowInsertableRelation, InsertableRelation, PrunedFilteredScan, BaseRelation, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. RowFormatRelation
  2. RowPutRelation
  3. PartitionedDataSourceScan
  4. JDBCMutableRelation
  5. Logging
  6. IndexableRelation
  7. DestroyRelation
  8. DeletableRelation
  9. UpdatableRelation
  10. RowInsertableRelation
  11. SingleRowInsertableRelation
  12. InsertableRelation
  13. PrunedFilteredScan
  14. BaseRelation
  15. AnyRef
  16. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new RowFormatRelation(_url: String, _table: String, _provider: String, preservepartitions: Boolean, _mode: SaveMode, _userSpecifiedString: String, _parts: Array[Partition], _poolProps: Map[String, String], _connProperties: Properties, _hikariCP: Boolean, _origOptions: Map[String, String], blockMap: Map[InternalDistributedMember, BlockManagerId], _context: SQLContext)

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def buildScan(requiredColumns: Array[String], filters: Array[Filter]): RDD[Row]

    Definition Classes
    RowFormatRelation → JDBCMutableRelation → PrunedFilteredScan
  8. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. val connProperties: Properties

    Definition Classes
    JDBCMutableRelation
  10. lazy val connectionType: columnar.ConnectionType.Value

  11. final lazy val connector: () ⇒ Connection

    Definition Classes
    JDBCMutableRelation
  12. def createIndex(tableName: String, sql: String): Unit

    Definition Classes
    JDBCMutableRelation → IndexableRelation
  13. def createTable(mode: SaveMode): String

    Definition Classes
    JDBCMutableRelation
  14. def delete(filterExpr: String): Int

    Definition Classes
    JDBCMutableRelation → DeletableRelation
  15. def destroy(ifExists: Boolean): Unit

    Definition Classes
    JDBCMutableRelation → DestroyRelation
  16. final val dialect: JdbcDialect

    Definition Classes
    JDBCMutableRelation
  17. val driver: String

    Definition Classes
    JDBCMutableRelation
  18. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  19. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  20. def executeUpdate(sql: String): Int

    Definition Classes
    JDBCMutableRelation → SingleRowInsertableRelation
  21. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  22. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  23. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  24. val hikariCP: Boolean

    Definition Classes
    JDBCMutableRelation
  25. def insert(rows: Seq[Row]): Int

    Definition Classes
    JDBCMutableRelation → RowInsertableRelation
  26. def insert(data: DataFrame): Unit

    Definition Classes
    JDBCMutableRelation
  27. def insert(data: DataFrame, mode: SaveMode): Unit

    Definition Classes
    JDBCMutableRelation
  28. def insert(data: DataFrame, overwrite: Boolean): Unit

    Definition Classes
    JDBCMutableRelation → InsertableRelation
  29. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  30. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  31. def log: Logger

    Attributes
    protected
    Definition Classes
    Logging
  32. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  33. def logDebug(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  34. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  35. def logError(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  36. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  37. def logInfo(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  38. def logName: String

    Attributes
    protected
    Definition Classes
    Logging
  39. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  40. def logTrace(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  41. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Attributes
    protected
    Definition Classes
    Logging
  42. def logWarning(msg: ⇒ String): Unit

    Attributes
    protected
    Definition Classes
    Logging
  43. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  44. val needConversion: Boolean

    Definition Classes
    JDBCMutableRelation → BaseRelation
  45. final def notify(): Unit

    Definition Classes
    AnyRef
  46. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  47. def numPartitions: Int

    We need to set num partitions just to cheat Exchange of Spark.

    We need to set num partitions just to cheat Exchange of Spark. This partition is not used for actual scan operator which depends on the actual RDD. Spark ClusteredDistribution is pretty simplistic to consider numShufflePartitions for its partitioning scheme as Spark always uses shuffle. Ideally it should consider child Spark plans partitioner.

    Definition Classes
    RowFormatRelation → PartitionedDataSourceScan
  48. val origOptions: Map[String, String]

    Definition Classes
    JDBCMutableRelation
  49. def partitionColumns: Seq[String]

    Definition Classes
    RowFormatRelation → PartitionedDataSourceScan
  50. val parts: Array[Partition]

    Definition Classes
    JDBCMutableRelation
  51. val poolProperties: Map[String, String]

    Definition Classes
    JDBCMutableRelation
  52. val provider: String

    Definition Classes
    JDBCMutableRelation
  53. def put(rows: Seq[Row]): Int

    If the row is already present, it gets updated otherwise it gets inserted into the table represented by this relation

    If the row is already present, it gets updated otherwise it gets inserted into the table represented by this relation

    rows

    the rows to be upserted

    returns

    number of rows upserted

    Definition Classes
    RowFormatRelation → RowPutRelation
  54. def put(data: DataFrame): Unit

    If the row is already present, it gets updated otherwise it gets inserted into the table represented by this relation

    If the row is already present, it gets updated otherwise it gets inserted into the table represented by this relation

    data

    the DataFrame to be upserted

    returns

    number of rows upserted

    Definition Classes
    RowFormatRelation → RowPutRelation
  55. final lazy val putStr: String

  56. final lazy val rowInsertStr: String

    Definition Classes
    JDBCMutableRelation
  57. final lazy val schema: StructType

    Definition Classes
    JDBCMutableRelation → BaseRelation
  58. final lazy val schemaFields: Map[String, StructField]

    Definition Classes
    JDBCMutableRelation
  59. def sizeInBytes: Long

    Definition Classes
    BaseRelation
  60. val sqlContext: SQLContext

    Definition Classes
    JDBCMutableRelation → BaseRelation
  61. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  62. val table: String

    Definition Classes
    JDBCMutableRelation
  63. var tableSchema: String

    Definition Classes
    JDBCMutableRelation
  64. def toString(): String

    Definition Classes
    RowFormatRelation → AnyRef → Any
  65. def truncate(): Unit

    Definition Classes
    JDBCMutableRelation → DestroyRelation
  66. def update(filterExpr: String, newColumnValues: Row, updateColumns: Seq[String]): Int

    Definition Classes
    JDBCMutableRelation → UpdatableRelation
  67. val url: String

    Definition Classes
    JDBCMutableRelation
  68. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  69. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  70. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from RowPutRelation

Inherited from PartitionedDataSourceScan

Inherited from JDBCMutableRelation

Inherited from Logging

Inherited from IndexableRelation

Inherited from DestroyRelation

Inherited from DeletableRelation

Inherited from UpdatableRelation

Inherited from RowInsertableRelation

Inherited from SingleRowInsertableRelation

Inherited from InsertableRelation

Inherited from PrunedFilteredScan

Inherited from BaseRelation

Inherited from AnyRef

Inherited from Any

Ungrouped