public class HiveContext extends SQLContext
SQLContext.implicits$
Constructor and Description |
---|
HiveContext(JavaSparkContext sc)
Deprecated.
|
HiveContext(SparkContext sc)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
HiveContext |
newSession()
Deprecated.
Returns a new HiveContext as new session, which will have separated SQLConf, UDF/UDAF,
temporary tables and SessionState, but sharing the same CacheManager, IsolatedClientLoader
and Hive client (both of execution and metadata) with existing HiveContext.
|
protected org.apache.spark.sql.hive.HiveSessionState |
sessionState()
Deprecated.
|
protected org.apache.spark.sql.hive.HiveSharedState |
sharedState()
Deprecated.
|
applySchemaToPythonRDD, applySchemaToPythonRDD, baseRelationToDataFrame, cacheManager, cacheTable, clearActive, clearCache, conf, createDataFrame, createDataFrame, createDataFrame, createDataFrame, createDataFrame, createDataFrame, createDataFrame, createDataFrame, createDataset, createDataset, createDataset, createExternalTable, createExternalTable, createExternalTable, createExternalTable, createExternalTable, createExternalTable, dropTempTable, emptyDataFrame, executePlan, executeSql, experimental, externalCatalog, getAllConfs, getConf, getConf, getOrCreate, implicits, initializeLogIfNecessary, isCached, isRootContext, isTraceEnabled, listener, listenerManager, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning, parseDataType, parseSql, range, range, range, range, read, runtimeConf, setActive, setConf, setConf, sparkContext, sparkSession, sql, streams, table, tableNames, tableNames, tables, tables, udf, uncacheTable
public HiveContext(SparkContext sc)
public HiveContext(JavaSparkContext sc)
public HiveContext newSession()
newSession
in class SQLContext
protected org.apache.spark.sql.hive.HiveSessionState sessionState()
sessionState
in class SQLContext
protected org.apache.spark.sql.hive.HiveSharedState sharedState()
sharedState
in class SQLContext