Modifier and Type | Method and Description |
---|---|
static HiveTablePartition |
HiveTablePartition.ofPartition(HiveConf hiveConf,
String hiveVersion,
String dbName,
String tableName,
LinkedHashMap<String,String> partitionSpec)
Creates a HiveTablePartition to represent a hive partition.
|
static HiveTablePartition |
HiveTablePartition.ofTable(HiveConf hiveConf,
String hiveVersion,
String dbName,
String tableName)
Creates a HiveTablePartition to represent a hive table.
|
Constructor and Description |
---|
HiveDynamicTableFactory(HiveConf hiveConf) |
Modifier and Type | Method and Description |
---|---|
static HiveConf |
HiveConfUtils.create(org.apache.hadoop.conf.Configuration conf)
Create HiveConf instance via Hadoop configuration.
|
Modifier and Type | Method and Description |
---|---|
static HiveConf |
HiveCatalog.createHiveConf(String hiveConfDir,
String hadoopConfDir) |
HiveConf |
HiveCatalog.getHiveConf() |
Modifier and Type | Method and Description |
---|---|
static CatalogLock.Factory |
HiveCatalogLock.createFactory(HiveConf hiveConf)
Deprecated.
Create a hive lock factory.
|
static boolean |
HiveCatalog.isEmbeddedMetastore(HiveConf hiveConf) |
Constructor and Description |
---|
HiveCatalog(String catalogName,
String defaultDatabase,
HiveConf hiveConf,
String hiveVersion) |
HiveCatalog(String catalogName,
String defaultDatabase,
HiveConf hiveConf,
String hiveVersion,
boolean allowEmbedded) |
Modifier and Type | Method and Description |
---|---|
static HiveMetastoreClientWrapper |
HiveMetastoreClientFactory.create(HiveConf hiveConf,
String hiveVersion) |
org.apache.hadoop.hive.metastore.IMetaStoreClient |
HiveShimV100.getHiveMetastoreClient(HiveConf hiveConf) |
org.apache.hadoop.hive.metastore.IMetaStoreClient |
HiveShimV310.getHiveMetastoreClient(HiveConf hiveConf) |
org.apache.hadoop.hive.metastore.IMetaStoreClient |
HiveShimV200.getHiveMetastoreClient(HiveConf hiveConf) |
org.apache.hadoop.hive.metastore.IMetaStoreClient |
HiveShim.getHiveMetastoreClient(HiveConf hiveConf)
Create a Hive Metastore client based on the given HiveConf object.
|
org.apache.hadoop.hive.metastore.IMetaStoreClient |
HiveShimV230.getHiveMetastoreClient(HiveConf hiveConf) |
org.apache.hadoop.hive.metastore.IMetaStoreClient |
HiveShimV120.getHiveMetastoreClient(HiveConf hiveConf) |
Constructor and Description |
---|
HiveMetastoreClientWrapper(HiveConf hiveConf,
HiveShim hiveShim) |
HiveMetastoreClientWrapper(HiveConf hiveConf,
String hiveVersion) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hive.metastore.api.Table |
HiveTableUtil.alterTableViaCatalogBaseTable(ObjectPath tablePath,
ResolvedCatalogBaseTable baseTable,
org.apache.hadoop.hive.metastore.api.Table oldHiveTable,
HiveConf hiveConf,
boolean managedTable) |
static Schema |
HiveTableUtil.createSchema(HiveConf hiveConf,
org.apache.hadoop.hive.metastore.api.Table hiveTable,
HiveMetastoreClientWrapper client,
HiveShim hiveShim)
Create a Flink's Schema by hive client.
|
static DataType |
HiveTableUtil.extractRowType(HiveConf hiveConf,
org.apache.hadoop.hive.metastore.api.Table hiveTable,
HiveMetastoreClientWrapper client,
HiveShim hiveShim)
Create the Hive table's row type.
|
static void |
HiveTableUtil.extractStoredAs(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
Map<String,String> properties,
HiveConf hiveConf) |
static List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
HiveTableUtil.getNonPartitionFields(HiveConf hiveConf,
org.apache.hadoop.hive.metastore.api.Table hiveTable,
HiveShim hiveShim) |
static org.apache.hadoop.hive.metastore.api.Table |
HiveTableUtil.instantiateHiveTable(ObjectPath tablePath,
ResolvedCatalogBaseTable table,
HiveConf hiveConf,
boolean managedTable) |
static void |
HiveTableUtil.setDefaultStorageFormat(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
HiveConf hiveConf) |
static void |
HiveTableUtil.setDefaultStorageFormatForDirectory(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
HiveConf hiveConf) |
static void |
HiveTableUtil.setStorageFormat(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
String format,
HiveConf hiveConf) |
Constructor and Description |
---|
HiveServer2Endpoint(SqlGatewayService service,
InetSocketAddress socketAddress,
long maxMessageSize,
int requestTimeoutMs,
int backOffSlotLengthMs,
int minWorkerThreads,
int maxWorkerThreads,
Duration workerKeepAliveTime,
String catalogName,
HiveConf hiveConf,
String defaultDatabase,
String moduleName) |
HiveServer2Endpoint(SqlGatewayService service,
InetSocketAddress socketAddress,
long maxMessageSize,
int requestTimeoutMs,
int backOffSlotLengthMs,
int minWorkerThreads,
int maxWorkerThreads,
Duration workerKeepAliveTime,
String catalogName,
HiveConf hiveConf,
String defaultDatabase,
String moduleName,
boolean allowEmbedded,
boolean isVerbose) |
Modifier and Type | Method and Description |
---|---|
static void |
HiveJdbcParameterUtils.setVariables(HiveConf hiveConf,
Map<String,String> sessionConfigs,
Map<String,String> parameters)
Use the to set or according to
what kinds of the parameter belongs.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
HiveParserUtils.isRegex(String pattern,
HiveConf conf)
Returns whether the pattern is a regex expression (instead of a normal string).
|
static void |
HiveParserUtils.saveViewDefinition(List<org.apache.hadoop.hive.metastore.api.FieldSchema> resultSchema,
HiveParserCreateViewInfo createViewInfo,
org.antlr.runtime.TokenRewriteStream tokenRewriteStream,
HiveParserUnparseTranslator unparseTranslator,
HiveConf conf) |
static void |
HiveSessionState.startSessionState(HiveConf hiveConf,
CatalogRegistry catalogRegistry) |
Constructor and Description |
---|
HiveParserScriptTransformHelper(org.apache.calcite.plan.RelOptCluster cluster,
LinkedHashMap<org.apache.calcite.rel.RelNode,HiveParserRowResolver> relToRowResolver,
LinkedHashMap<org.apache.calcite.rel.RelNode,Map<String,Integer>> relToHiveColNameCalcitePosMap,
HiveConf hiveConf) |
HiveSessionState(HiveConf conf,
ClassLoader contextLoader) |
Modifier and Type | Method and Description |
---|---|
HiveConf |
HiveParserQueryState.getConf() |
HiveConf |
HiveParserSemanticAnalyzer.getConf() |
Modifier and Type | Method and Description |
---|---|
static List<String> |
HiveSetProcessor.dumpOptions(Properties p,
HiveConf hiveConf,
Map<String,String> hiveVariables,
TableConfig tableConfig) |
static String |
HiveSetProcessor.getVariable(Map<String,String> flinkConf,
HiveConf hiveConf,
Map<String,String> hiveVariables,
String varname) |
static void |
HiveParserBaseSemanticAnalyzer.processPositionAlias(HiveParserASTNode ast,
HiveConf conf) |
static void |
HiveSetProcessor.setVariable(HiveConf hiveConf,
Map<String,String> hiveVariables,
String varname,
String varvalue)
Set variable following Hive's implementation.
|
static void |
HiveParserBaseSemanticAnalyzer.validatePartColumnType(ResolvedCatalogTable resolvedCatalogTable,
Map<String,String> partSpec,
HiveParserASTNode astNode,
HiveConf conf,
org.apache.calcite.tools.FrameworkConfig frameworkConfig,
org.apache.calcite.plan.RelOptCluster cluster) |
Constructor and Description |
---|
HiveParserQueryState(HiveConf conf) |
HiveParserQueryState(HiveConf conf,
Map<String,String> confOverlay,
boolean runAsync) |
TableSpec(CatalogRegistry catalogRegistry,
HiveConf conf,
HiveParserASTNode ast,
org.apache.calcite.tools.FrameworkConfig frameworkConfig,
org.apache.calcite.plan.RelOptCluster cluster) |
Constructor and Description |
---|
HiveParserLoadSemanticAnalyzer(HiveConf conf,
org.apache.calcite.tools.FrameworkConfig frameworkConfig,
org.apache.calcite.plan.RelOptCluster cluster,
CatalogRegistry catalogRegistry) |
Modifier and Type | Method and Description |
---|---|
static HiveConf |
HiveCatalogUtils.getHiveConf(Catalog catalog) |
Constructor and Description |
---|
HiveConf(HiveConf other)
Copy constructor
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.