Package org.apache.spark.sql.jdbc
Class OracleDialect
Object
org.apache.spark.sql.jdbc.OracleDialect
-
Nested Class Summary
Modifier and TypeClassDescriptionstatic class
static class
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionstatic String[]
alterTable
(String tableName, scala.collection.Seq<TableChange> changes, int dbMajorVersion) static void
beforeFetch
(Connection connection, scala.collection.immutable.Map<String, String> properties) abstract static boolean
static boolean
static AnalysisException
classifyException
(String message, Throwable e) static scala.Option<String>
compileAggregate
(AggregateFunc aggFunction) static scala.Option<String>
compileExpression
(Expression expr) static Object
compileValue
(Object value) static Timestamp
static LocalDateTime
static Timestamp
static scala.Function1<Object,
Connection> createConnectionFactory
(org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) static String
createIndex
(String indexName, Identifier tableIdent, NamedReference[] columns, Map<NamedReference, Map<String, String>> columnsProperties, Map<String, String> properties) static void
createSchema
(Statement statement, String schema, String comment) static void
createTable
(Statement statement, String tableName, String strSchema, org.apache.spark.sql.execution.datasources.jdbc.JdbcOptionsInWrite options) static String
dropIndex
(String indexName, Identifier tableIdent) static String
dropSchema
(String schema, boolean cascade) abstract static boolean
static scala.collection.Seq<scala.Tuple2<String,
UnboundFunction>> static String
getAddColumnQuery
(String tableName, String columnName, String dataType) static scala.Option<DataType>
getCatalystType
(int sqlType, String typeName, int size, MetadataBuilder md) static String
getDeleteColumnQuery
(String tableName, String columnName) static String
static JdbcSQLQueryBuilder
getJdbcSQLQueryBuilder
(org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) static scala.Option<JdbcType>
getJDBCType
(DataType dt) static String
getLimitClause
(Integer limit) static String
getOffsetClause
(Integer offset) static String
getRenameColumnQuery
(String tableName, String columnName, String newName, int dbMajorVersion) static String
getSchemaCommentQuery
(String schema, String comment) static String
getSchemaQuery
(String table) static String
getTableCommentQuery
(String table, String comment) static String
getTableExistsQuery
(String table) static String
getTableSample
(org.apache.spark.sql.execution.datasources.v2.TableSampleInfo sample) static String
getTruncateQuery
(String table, scala.Option<Object> cascade) The SQL query used to truncate a table.static scala.Option<Object>
static String
getUpdateColumnNullabilityQuery
(String tableName, String columnName, boolean isNullable) static String
getUpdateColumnTypeQuery
(String tableName, String columnName, String newDataType) static boolean
indexExists
(Connection conn, String indexName, Identifier tableIdent, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) static scala.Option<Object>
static boolean
isSupportedFunction
(String funcName) static TableIndex[]
listIndexes
(Connection conn, Identifier tableIdent, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) static String[][]
listSchemas
(Connection conn, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) static org.slf4j.Logger
static void
org$apache$spark$internal$Logging$$log__$eq
(org.slf4j.Logger x$1) abstract static int
abstract static Object
productElement
(int n) static scala.collection.Iterator<Object>
static String
static String
quoteIdentifier
(String colName) static String
removeSchemaCommentQuery
(String schema) static String
renameTable
(String oldTable, String newTable) static String
renameTable
(Identifier oldTable, Identifier newTable) static boolean
schemasExists
(Connection conn, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options, String schema) static boolean
static boolean
static boolean
-
Constructor Details
-
OracleDialect
public OracleDialect()
-
-
Method Details
-
canHandle
-
isSupportedFunction
-
compileExpression
-
getCatalystType
public static scala.Option<DataType> getCatalystType(int sqlType, String typeName, int size, MetadataBuilder md) -
getJDBCType
-
compileValue
-
isCascadingTruncateTable
-
getTruncateQuery
The SQL query used to truncate a table.- Parameters:
table
- The table to truncatecascade
- Whether or not to cascade the truncation. Default value is the value of isCascadingTruncateTable()- Returns:
- The SQL query to use for truncating a table
-
getAddColumnQuery
-
getUpdateColumnTypeQuery
-
getUpdateColumnNullabilityQuery
-
getLimitClause
-
getOffsetClause
-
getJdbcSQLQueryBuilder
public static JdbcSQLQueryBuilder getJdbcSQLQueryBuilder(org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) -
supportsLimit
public static boolean supportsLimit() -
supportsOffset
public static boolean supportsOffset() -
convertJavaTimestampToTimestamp
-
convertJavaTimestampToTimestampNTZ
-
convertTimestampNTZToJavaTimestamp
-
createConnectionFactory
public static scala.Function1<Object,Connection> createConnectionFactory(org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) -
quoteIdentifier
-
createTable
-
getTableExistsQuery
-
getSchemaQuery
-
getTruncateQuery$default$2
-
beforeFetch
public static void beforeFetch(Connection connection, scala.collection.immutable.Map<String, String> properties) -
compileAggregate
-
functions
-
createSchema
-
schemasExists
public static boolean schemasExists(Connection conn, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options, String schema) -
listSchemas
public static String[][] listSchemas(Connection conn, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) -
renameTable
-
renameTable
-
alterTable
public static String[] alterTable(String tableName, scala.collection.Seq<TableChange> changes, int dbMajorVersion) -
getRenameColumnQuery
-
getDeleteColumnQuery
-
getTableCommentQuery
-
getSchemaCommentQuery
-
removeSchemaCommentQuery
-
dropSchema
-
createIndex
public static String createIndex(String indexName, Identifier tableIdent, NamedReference[] columns, Map<NamedReference, Map<String, String>> columnsProperties, Map<String, String> properties) -
indexExists
public static boolean indexExists(Connection conn, String indexName, Identifier tableIdent, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) -
dropIndex
-
listIndexes
public static TableIndex[] listIndexes(Connection conn, Identifier tableIdent, org.apache.spark.sql.execution.datasources.jdbc.JDBCOptions options) -
classifyException
-
supportsTableSample
public static boolean supportsTableSample() -
getTableSample
public static String getTableSample(org.apache.spark.sql.execution.datasources.v2.TableSampleInfo sample) -
getFullyQualifiedQuotedTableName
-
org$apache$spark$internal$Logging$$log_
public static org.slf4j.Logger org$apache$spark$internal$Logging$$log_() -
org$apache$spark$internal$Logging$$log__$eq
public static void org$apache$spark$internal$Logging$$log__$eq(org.slf4j.Logger x$1) -
canEqual
-
equals
-
productElement
-
productArity
public abstract static int productArity() -
productIterator
-
productPrefix
-