org.apache.spark.sql.crossdata.catalog

PostgreSQLCatalog

class PostgreSQLCatalog extends XDCatalog with SparkLoggerComponent

Default implementation of the org.apache.spark.sql.crossdata.catalog.XDCatalog with persistence using Jdbc. Supported MySQL and PostgreSQL

Linear Supertypes
XDCatalog, Serializable, Serializable, CatalogCommon, SparkLoggerComponent, Logging, LoggerComponent, Catalog, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. PostgreSQLCatalog
  2. XDCatalog
  3. Serializable
  4. Serializable
  5. CatalogCommon
  6. SparkLoggerComponent
  7. Logging
  8. LoggerComponent
  9. Catalog
  10. AnyRef
  11. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new PostgreSQLCatalog(conf: CatalystConf = ..., xdContext: XDContext)

    conf

    An implementation of the CatalystConf.

Type Members

  1. trait Logger extends AnyRef

    Definition Classes
    LoggerComponent
  2. class SparkLogger extends com.stratio.common.utils.components.logger.impl.SparkLoggerComponent.Logger

    Definition Classes
    SparkLoggerComponent

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 checkConnectivity: Boolean

    Check the connection to the set Catalog

    Check the connection to the set Catalog

    Definition Classes
    PostgreSQLCatalogXDCatalog
  8. def clone(): AnyRef

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

    An implementation of the CatalystConf.

    An implementation of the CatalystConf.

    Definition Classes
    PostgreSQLCatalogXDCatalog → Catalog
  10. lazy val connection: Connection

  11. def createLogicalRelation(crossdataTable: CrossdataTable): LogicalRelation

    Attributes
    protected[org.apache.spark.sql.crossdata]
    Definition Classes
    XDCatalog
  12. def dropAllPersistedTables(): Unit

    Definition Classes
    PostgreSQLCatalogXDCatalog
  13. def dropAllPersistedViews(): Unit

    Attributes
    protected
    Definition Classes
    PostgreSQLCatalogXDCatalog
  14. final def dropAllTables(): Unit

    Definition Classes
    XDCatalog
  15. final def dropAllViews(): Unit

    Definition Classes
    XDCatalog
  16. def dropPersistedTable(tableIdentifier: TableIdentifier): Unit

    Drop table(s)/view(s) if exists.

    Drop table(s)/view(s) if exists.

    Definition Classes
    PostgreSQLCatalogXDCatalog
  17. def dropPersistedView(viewIdentifier: ViewIdentifier): Unit

    Attributes
    protected
    Definition Classes
    PostgreSQLCatalogXDCatalog
  18. final def dropTable(tableIdentifier: TableIdentifier): Unit

    Definition Classes
    XDCatalog
  19. final def dropView(viewIdentifier: ViewIdentifier): Unit

    Definition Classes
    XDCatalog
  20. final def eq(arg0: AnyRef): Boolean

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

    Definition Classes
    AnyRef → Any
  22. def finalize(): Unit

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

    Definition Classes
    AnyRef → Any
  24. def getTableName(tableIdent: TableIdentifier): String

    Get the table name of TableIdentifier for temporary tables.

    Get the table name of TableIdentifier for temporary tables.

    Attributes
    protected
    Definition Classes
    XDCatalog → Catalog
  25. def getTables(databaseName: Option[String]): Seq[(String, Boolean)]

    Definition Classes
    XDCatalog → Catalog
  26. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  27. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  28. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  29. def listPersistedTables(databaseName: Option[String]): Seq[(String, Boolean)]

    Definition Classes
    PostgreSQLCatalogXDCatalog
  30. def log: slf4j.Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  37. def logName: String

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  42. val logger: Logger

    Definition Classes
    SparkLoggerComponent → LoggerComponent
  43. def lookupRelation(relationIdentifier: TableIdentifier, alias: Option[String]): LogicalPlan

    Definition Classes
    XDCatalog → Catalog
  44. def lookupRelationCache(tableIdentifier: TableIdentifier, alias: Option[String]): Option[LogicalPlan]

    Definition Classes
    XDCatalog
  45. def lookupTable(tableIdentifier: TableIdentifier): Option[CrossdataTable]

    Definition Classes
    PostgreSQLCatalogXDCatalog
  46. def lookupView(viewIdentifier: ViewIdentifier): Option[String]

    Attributes
    protected
    Definition Classes
    PostgreSQLCatalogXDCatalog
  47. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  48. def notFound(resource: String): Nothing

    Attributes
    protected
    Definition Classes
    CatalogCommon
  49. final def notify(): Unit

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

    Definition Classes
    AnyRef
  51. final def persistTable(crossdataTable: CrossdataTable, table: LogicalPlan): Unit

    Definition Classes
    XDCatalog
  52. def persistTableMetadata(crossdataTable: CrossdataTable): Unit

    Definition Classes
    PostgreSQLCatalogXDCatalog
  53. final def persistView(tableIdentifier: ViewIdentifier, plan: LogicalPlan, sqlText: String): Unit

    Definition Classes
    XDCatalog
  54. def persistViewMetadata(tableIdentifier: TableIdentifier, sqlText: String): Unit

    Attributes
    protected[org.apache.spark.sql.crossdata]
    Definition Classes
    PostgreSQLCatalogXDCatalog
  55. def refreshTable(tableIdentifier: TableIdentifier): Unit

    Definition Classes
    XDCatalog → Catalog
  56. def registerTable(tableIdentifier: TableIdentifier, plan: LogicalPlan): Unit

    Definition Classes
    XDCatalog → Catalog
  57. def registerView(tableIdentifier: ViewIdentifier, plan: LogicalPlan): Unit

    Definition Classes
    XDCatalog
  58. def schemaExists(schema: String, connection: Connection): Boolean

  59. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  60. def tableExists(tableIdentifier: TableIdentifier): Boolean

    Definition Classes
    XDCatalog → Catalog
  61. def tableExistsInPersistedCatalog(tableIdentifier: TableIdentifier): Boolean

    Definition Classes
    XDCatalog
  62. val tables: HashMap[String, LogicalPlan]

    Definition Classes
    XDCatalog
  63. def toString(): String

    Definition Classes
    AnyRef → Any
  64. def unregisterAllTables(): Unit

    Definition Classes
    XDCatalog → Catalog
  65. def unregisterTable(tableIdentifier: TableIdentifier): Unit

    Definition Classes
    XDCatalog → Catalog
  66. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from XDCatalog

Inherited from Serializable

Inherited from Serializable

Inherited from CatalogCommon

Inherited from SparkLoggerComponent

Inherited from Logging

Inherited from LoggerComponent

Inherited from Catalog

Inherited from AnyRef

Inherited from Any

Ungrouped