|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of HiveConf in org.apache.hadoop.hive.cli |
---|
Constructors in org.apache.hadoop.hive.cli with parameters of type HiveConf | |
---|---|
CliSessionState(HiveConf conf)
|
Uses of HiveConf in org.apache.hadoop.hive.common |
---|
Methods in org.apache.hadoop.hive.common with parameters of type HiveConf | |
---|---|
static void |
ServerUtils.cleanUpScratchDir(HiveConf hiveConf)
|
Uses of HiveConf in org.apache.hadoop.hive.conf |
---|
Constructors in org.apache.hadoop.hive.conf with parameters of type HiveConf | |
---|---|
HiveConf(HiveConf other)
Copy constructor |
Uses of HiveConf in org.apache.hadoop.hive.jdbc |
---|
Constructors in org.apache.hadoop.hive.jdbc with parameters of type HiveConf | |
---|---|
HiveConnection(HiveConf hiveConf)
Create a connection to a local Hive |
Uses of HiveConf in org.apache.hadoop.hive.metastore |
---|
Fields in org.apache.hadoop.hive.metastore declared as HiveConf | |
---|---|
protected HiveConf |
TestMetaStoreAuthorization.conf
|
protected HiveConf |
TestMarkPartition.hiveConf
|
protected static HiveConf |
TestHiveMetaStore.hiveConf
|
Methods in org.apache.hadoop.hive.metastore that return HiveConf | |
---|---|
HiveConf |
HiveMetaStore.HMSHandler.getHiveConf()
|
Methods in org.apache.hadoop.hive.metastore with parameters of type HiveConf | |
---|---|
static RawStore |
RetryingRawStore.getProxy(HiveConf hiveConf,
org.apache.hadoop.conf.Configuration conf,
String rawStoreClassName,
int id)
|
static IMetaStoreClient |
RetryingMetaStoreClient.getProxy(HiveConf hiveConf,
HiveMetaHookLoader hookLoader,
String mscClassName)
|
static IHMSHandler |
RetryingHMSHandler.getProxy(HiveConf hiveConf,
String name)
|
static void |
MetaStoreUtils.makeDir(org.apache.hadoop.fs.Path path,
HiveConf hiveConf)
|
static IHMSHandler |
HiveMetaStore.newHMSHandler(String name,
HiveConf hiveConf)
|
static void |
TestHiveMetaStore.partitionTester(HiveMetaStoreClient client,
HiveConf hiveConf)
|
static void |
HiveMetaStore.startMetaStore(int port,
HadoopThriftAuthBridge bridge,
HiveConf conf)
Start Metastore based on a passed HadoopThriftAuthBridge |
Constructors in org.apache.hadoop.hive.metastore with parameters of type HiveConf | |
---|---|
HiveMetaStore.HMSHandler(String name,
HiveConf conf)
|
|
HiveMetaStoreClient(HiveConf conf)
|
|
HiveMetaStoreClient(HiveConf conf,
HiveMetaHookLoader hookLoader)
|
|
RetryingHMSHandler(HiveConf hiveConf,
String name)
|
|
RetryingMetaStoreClient(HiveConf hiveConf,
HiveMetaHookLoader hookLoader,
Class<? extends IMetaStoreClient> msClientClass)
|
|
RetryingRawStore(HiveConf hiveConf,
org.apache.hadoop.conf.Configuration conf,
Class<? extends RawStore> rawStoreClass,
int id)
|
Uses of HiveConf in org.apache.hadoop.hive.ql |
---|
Fields in org.apache.hadoop.hive.ql declared as HiveConf | |
---|---|
protected HiveConf |
QTestUtil.conf
|
Methods in org.apache.hadoop.hive.ql with parameters of type HiveConf | |
---|---|
static Schema |
Driver.getSchema(BaseSemanticAnalyzer sem,
HiveConf conf)
Get a Schema with fields represented with native Hive types |
void |
QTestUtil.QTestSetup.postTest(HiveConf conf)
|
void |
QTestUtil.QTestSetup.preTest(HiveConf conf)
|
Constructors in org.apache.hadoop.hive.ql with parameters of type HiveConf | |
---|---|
Driver(HiveConf conf)
for backwards compatibility with current tests |
Uses of HiveConf in org.apache.hadoop.hive.ql.exec |
---|
Fields in org.apache.hadoop.hive.ql.exec declared as HiveConf | |
---|---|
protected HiveConf |
Task.conf
|
Methods in org.apache.hadoop.hive.ql.exec with parameters of type HiveConf | ||
---|---|---|
static String |
ExecDriver.generateCmdLine(HiveConf hconf,
Context ctx)
Given a Hive Configuration object - generate a command line fragment for passing such configuration information to ExecDriver. |
|
static
|
TaskFactory.get(Class<T> workClass,
HiveConf conf)
|
|
static
|
TaskFactory.get(T work,
HiveConf conf,
Task<? extends Serializable>... tasklist)
|
|
static
|
TaskFactory.getAndMakeChild(T work,
HiveConf conf,
Task<? extends Serializable>... tasklist)
|
|
void |
Task.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext driverContext)
|
|
void |
MapredLocalTask.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext driverContext)
|
|
void |
FunctionTask.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext ctx)
|
|
void |
FetchTask.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext ctx)
|
|
void |
ExecDriver.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext driverContext)
Initialization when invoked from QL. |
|
void |
DDLTask.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext ctx)
|
|
void |
ConditionalTask.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext driverContext)
|
|
void |
ColumnStatsTask.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext ctx)
|
|
static String |
MapRedTask.isEligibleForLocalMode(HiveConf conf,
int numReducers,
long inputLength,
long inputFileCount)
Find out if a job can be run in local mode based on it's characteristics |
|
static void |
Utilities.reworkMapRedWork(Task<? extends Serializable> task,
boolean reworkMapredWork,
HiveConf conf)
The check here is kind of not clean. |
Constructors in org.apache.hadoop.hive.ql.exec with parameters of type HiveConf | |
---|---|
ArchiveUtils.HarPathHelper(HiveConf hconf,
URI archive,
URI originalBase)
Creates helper for archive. |
Uses of HiveConf in org.apache.hadoop.hive.ql.hooks |
---|
Methods in org.apache.hadoop.hive.ql.hooks that return HiveConf | |
---|---|
HiveConf |
HookContext.getConf()
|
Methods in org.apache.hadoop.hive.ql.hooks with parameters of type HiveConf | |
---|---|
void |
HookContext.setConf(HiveConf conf)
|
Constructors in org.apache.hadoop.hive.ql.hooks with parameters of type HiveConf | |
---|---|
HookContext(QueryPlan queryPlan,
HiveConf conf)
|
|
HookContext(QueryPlan queryPlan,
HiveConf conf,
Map<String,org.apache.hadoop.fs.ContentSummary> inputPathToContentSummary)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.index |
---|
Methods in org.apache.hadoop.hive.ql.index with parameters of type HiveConf | |
---|---|
boolean |
HiveIndexHandler.checkQuerySize(long inputSize,
HiveConf conf)
Check the size of an input query to make sure it fits within the bounds |
boolean |
AbstractIndexHandler.checkQuerySize(long inputSize,
HiveConf conf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.index.bitmap |
---|
Methods in org.apache.hadoop.hive.ql.index.bitmap with parameters of type HiveConf | |
---|---|
boolean |
BitmapIndexHandler.checkQuerySize(long querySize,
HiveConf hiveConf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.index.compact |
---|
Methods in org.apache.hadoop.hive.ql.index.compact with parameters of type HiveConf | |
---|---|
boolean |
CompactIndexHandler.checkQuerySize(long querySize,
HiveConf hiveConf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.io |
---|
Methods in org.apache.hadoop.hive.ql.io with parameters of type HiveConf | |
---|---|
static boolean |
HiveFileFormatUtils.checkInputFormat(org.apache.hadoop.fs.FileSystem fs,
HiveConf conf,
Class<? extends org.apache.hadoop.mapred.InputFormat> inputFormatCls,
ArrayList<org.apache.hadoop.fs.FileStatus> files)
checks if files are in same format as the given input format. |
void |
SymbolicInputFormat.rework(HiveConf job,
MapredWork work)
|
void |
ReworkMapredInputFormat.rework(HiveConf job,
MapredWork work)
|
boolean |
SequenceFileInputFormatChecker.validateInput(org.apache.hadoop.fs.FileSystem fs,
HiveConf conf,
ArrayList<org.apache.hadoop.fs.FileStatus> files)
|
boolean |
RCFileInputFormat.validateInput(org.apache.hadoop.fs.FileSystem fs,
HiveConf conf,
ArrayList<org.apache.hadoop.fs.FileStatus> files)
|
boolean |
InputFormatChecker.validateInput(org.apache.hadoop.fs.FileSystem fs,
HiveConf conf,
ArrayList<org.apache.hadoop.fs.FileStatus> files)
This method is used to validate the input files. |
Uses of HiveConf in org.apache.hadoop.hive.ql.io.rcfile.merge |
---|
Methods in org.apache.hadoop.hive.ql.io.rcfile.merge with parameters of type HiveConf | |
---|---|
void |
BlockMergeTask.initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext driverContext)
|
void |
MergeWork.resolveDynamicPartitionMerge(HiveConf conf,
org.apache.hadoop.fs.Path path,
TableDesc tblDesc,
ArrayList<String> aliases,
PartitionDesc partDesc)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.lockmgr |
---|
Methods in org.apache.hadoop.hive.ql.lockmgr that return HiveConf | |
---|---|
HiveConf |
HiveLockManagerCtx.getConf()
|
Methods in org.apache.hadoop.hive.ql.lockmgr with parameters of type HiveConf | |
---|---|
void |
HiveLockManagerCtx.setConf(HiveConf conf)
|
Constructors in org.apache.hadoop.hive.ql.lockmgr with parameters of type HiveConf | |
---|---|
HiveLockManagerCtx(HiveConf conf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.lockmgr.zookeeper |
---|
Methods in org.apache.hadoop.hive.ql.lockmgr.zookeeper with parameters of type HiveConf | |
---|---|
static void |
ZooKeeperHiveLockManager.releaseAllLocks(HiveConf conf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.metadata |
---|
Fields in org.apache.hadoop.hive.ql.metadata declared as HiveConf | |
---|---|
protected HiveConf |
TestHive.hiveConf
|
Methods in org.apache.hadoop.hive.ql.metadata that return HiveConf | |
---|---|
HiveConf |
Hive.getConf()
|
Methods in org.apache.hadoop.hive.ql.metadata with parameters of type HiveConf | |
---|---|
protected static void |
Hive.copyFiles(HiveConf conf,
org.apache.hadoop.fs.Path srcf,
org.apache.hadoop.fs.Path destf,
org.apache.hadoop.fs.FileSystem fs)
|
static Hive |
Hive.get(HiveConf c)
Gets hive object for the current thread. |
static Hive |
Hive.get(HiveConf c,
boolean needsRefresh)
get a connection to metastore. |
static HiveIndexHandler |
HiveUtils.getIndexHandler(HiveConf conf,
String indexHandlerClass)
|
protected static void |
Hive.replaceFiles(org.apache.hadoop.fs.Path srcf,
org.apache.hadoop.fs.Path destf,
org.apache.hadoop.fs.Path oldPath,
HiveConf conf)
Replaces files in the partition with new data set specified by srcf. |
Uses of HiveConf in org.apache.hadoop.hive.ql.metadata.formatting |
---|
Methods in org.apache.hadoop.hive.ql.metadata.formatting with parameters of type HiveConf | |
---|---|
void |
TextMetaDataFormatter.showTableStatus(DataOutputStream outStream,
Hive db,
HiveConf conf,
List<Table> tbls,
Map<String,String> part,
Partition par)
|
void |
MetaDataFormatter.showTableStatus(DataOutputStream out,
Hive db,
HiveConf conf,
List<Table> tbls,
Map<String,String> part,
Partition par)
Show the table status. |
void |
JsonMetaDataFormatter.showTableStatus(DataOutputStream out,
Hive db,
HiveConf conf,
List<Table> tbls,
Map<String,String> part,
Partition par)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.optimizer |
---|
Methods in org.apache.hadoop.hive.ql.optimizer that return HiveConf | |
---|---|
HiveConf |
GroupByOptimizer.GroupByOptimizerContext.getConf()
|
HiveConf |
GenMRProcContext.getConf()
|
Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type HiveConf | |
---|---|
static Task<?> |
IndexUtils.createRootTask(HiveConf builderConf,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs,
StringBuilder command,
LinkedHashMap<String,String> partSpec,
String indexTableName,
String dbName)
|
static MapredWork |
GenMapRedUtils.getMapRedWorkFromConf(HiveConf conf)
create a new plan and return. |
void |
Optimizer.initialize(HiveConf hiveConf)
Create the list of transformations. |
void |
GroupByOptimizer.GroupByOptimizerContext.setConf(HiveConf conf)
|
void |
GenMRProcContext.setConf(HiveConf conf)
|
Constructors in org.apache.hadoop.hive.ql.optimizer with parameters of type HiveConf | |
---|---|
GenMRProcContext(HiveConf conf,
HashMap<Operator<? extends OperatorDesc>,Task<? extends Serializable>> opTaskMap,
List<Operator<? extends OperatorDesc>> seenOps,
ParseContext parseCtx,
List<Task<MoveWork>> mvTask,
List<Task<? extends Serializable>> rootTasks,
LinkedHashMap<Operator<? extends OperatorDesc>,GenMRProcContext.GenMapRedCtx> mapCurrCtx,
Set<ReadEntity> inputs,
Set<WriteEntity> outputs)
|
|
GroupByOptimizer.GroupByOptimizerContext(HiveConf conf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.optimizer.index |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.index with parameters of type HiveConf | |
---|---|
static ParseContext |
RewriteParseContextGenerator.generateOperatorTree(HiveConf conf,
String command)
Parse the input String command and generate a ASTNode tree. |
Uses of HiveConf in org.apache.hadoop.hive.ql.optimizer.physical |
---|
Fields in org.apache.hadoop.hive.ql.optimizer.physical declared as HiveConf | |
---|---|
protected HiveConf |
PhysicalContext.conf
|
Methods in org.apache.hadoop.hive.ql.optimizer.physical that return HiveConf | |
---|---|
HiveConf |
PhysicalContext.getConf()
|
Methods in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type HiveConf | |
---|---|
void |
PhysicalContext.setConf(HiveConf conf)
|
static boolean |
GenMRSkewJoinProcessor.skewJoinEnabled(HiveConf conf,
JoinOperator joinOp)
|
Constructors in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type HiveConf | |
---|---|
PhysicalContext(HiveConf conf,
ParseContext parseContext,
Context context,
List<Task<? extends Serializable>> rootTasks,
Task<? extends Serializable> fetchTask)
|
|
PhysicalOptimizer(PhysicalContext pctx,
HiveConf hiveConf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.optimizer.ppr |
---|
Methods in org.apache.hadoop.hive.ql.optimizer.ppr with parameters of type HiveConf | |
---|---|
static PrunedPartitionList |
PartitionPruner.prune(Table tab,
ExprNodeDesc prunerExpr,
HiveConf conf,
String alias,
Map<String,PrunedPartitionList> prunedPartitionsMap)
Get the partition list for the table that satisfies the partition pruner condition. |
Uses of HiveConf in org.apache.hadoop.hive.ql.parse |
---|
Fields in org.apache.hadoop.hive.ql.parse declared as HiveConf | |
---|---|
protected HiveConf |
BaseSemanticAnalyzer.conf
|
Methods in org.apache.hadoop.hive.ql.parse that return HiveConf | |
---|---|
HiveConf |
ParseContext.getConf()
|
Methods in org.apache.hadoop.hive.ql.parse with parameters of type HiveConf | |
---|---|
static BaseSemanticAnalyzer |
SemanticAnalyzerFactory.get(HiveConf conf,
ASTNode tree)
|
static String |
EximUtil.relativeToAbsolutePath(HiveConf conf,
String location)
|
void |
ParseContext.setConf(HiveConf conf)
|
String |
VariableSubstitution.substitute(HiveConf conf,
String expr)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.plan |
---|
Methods in org.apache.hadoop.hive.ql.plan with parameters of type HiveConf | |
---|---|
List<Task<? extends Serializable>> |
ConditionalResolverSkewJoin.getTasks(HiveConf conf,
Object objCtx)
|
List<Task<? extends Serializable>> |
ConditionalResolverMergeFiles.getTasks(HiveConf conf,
Object objCtx)
|
List<Task<? extends Serializable>> |
ConditionalResolverCommonJoin.getTasks(HiveConf conf,
Object objCtx)
|
List<Task<? extends Serializable>> |
ConditionalResolver.getTasks(HiveConf conf,
Object ctx)
All conditional resolvers implement this interface. |
void |
MapredWork.resolveDynamicPartitionMerge(HiveConf conf,
org.apache.hadoop.fs.Path path,
TableDesc tblDesc,
ArrayList<String> aliases,
PartitionDesc partDesc)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.processors |
---|
Methods in org.apache.hadoop.hive.ql.processors with parameters of type HiveConf | |
---|---|
static void |
CommandProcessorFactory.clean(HiveConf conf)
|
static CommandProcessor |
CommandProcessorFactory.get(String cmd,
HiveConf conf)
|
Uses of HiveConf in org.apache.hadoop.hive.ql.session |
---|
Fields in org.apache.hadoop.hive.ql.session declared as HiveConf | |
---|---|
protected HiveConf |
SessionState.conf
current configuration. |
Methods in org.apache.hadoop.hive.ql.session that return HiveConf | |
---|---|
HiveConf |
SessionState.getConf()
|
Methods in org.apache.hadoop.hive.ql.session with parameters of type HiveConf | |
---|---|
static CreateTableAutomaticGrant |
CreateTableAutomaticGrant.create(HiveConf conf)
|
void |
SessionState.setConf(HiveConf conf)
|
static SessionState |
SessionState.start(HiveConf conf)
start a new session and set it to current session. |
Constructors in org.apache.hadoop.hive.ql.session with parameters of type HiveConf | |
---|---|
SessionState(HiveConf conf)
|
Uses of HiveConf in org.apache.hadoop.hive.service |
---|
Constructors in org.apache.hadoop.hive.service with parameters of type HiveConf | |
---|---|
HiveServer.HiveServerHandler(HiveConf conf)
Construct a new handler with the specified hive configuration. |
|
HiveServer.ThriftHiveProcessorFactory(org.apache.thrift.TProcessor processor,
HiveConf conf)
|
Uses of HiveConf in org.apache.hive.cli.beeline.util |
---|
Constructors in org.apache.hive.cli.beeline.util with parameters of type HiveConf | |
---|---|
QFileClient(HiveConf hiveConf,
String hiveRootDirectory,
String qFileDirectory,
String outputDirectory,
String expectedDirectory)
|
Uses of HiveConf in org.apache.hive.service |
---|
Methods in org.apache.hive.service that return HiveConf | |
---|---|
HiveConf |
Service.getHiveConf()
Get the configuration of this service. |
HiveConf |
FilterService.getHiveConf()
|
HiveConf |
AbstractService.getHiveConf()
|
Methods in org.apache.hive.service with parameters of type HiveConf | |
---|---|
static void |
ServiceOperations.deploy(Service service,
HiveConf configuration)
Initialize then start a service. |
void |
Service.init(HiveConf conf)
Initialize the service. |
void |
FilterService.init(HiveConf config)
|
void |
CompositeService.init(HiveConf hiveConf)
|
void |
BreakableService.init(HiveConf conf)
|
void |
AbstractService.init(HiveConf hiveConf)
Initialize the service. |
static void |
ServiceOperations.init(Service service,
HiveConf configuration)
Initialize a service. |
Uses of HiveConf in org.apache.hive.service.cli |
---|
Methods in org.apache.hive.service.cli with parameters of type HiveConf | |
---|---|
void |
CLIService.init(HiveConf hiveConf)
|
Uses of HiveConf in org.apache.hive.service.cli.operation |
---|
Methods in org.apache.hive.service.cli.operation that return HiveConf | |
---|---|
HiveConf |
Operation.getConfiguration()
|
Methods in org.apache.hive.service.cli.operation with parameters of type HiveConf | |
---|---|
void |
OperationManager.init(HiveConf hiveConf)
|
void |
Operation.setConfiguration(HiveConf configuration)
|
Uses of HiveConf in org.apache.hive.service.cli.session |
---|
Methods in org.apache.hive.service.cli.session that return HiveConf | |
---|---|
HiveConf |
Session.getHiveConf()
|
Methods in org.apache.hive.service.cli.session with parameters of type HiveConf | |
---|---|
void |
SessionManager.init(HiveConf hiveConf)
|
Uses of HiveConf in org.apache.hive.service.cli.thrift |
---|
Methods in org.apache.hive.service.cli.thrift with parameters of type HiveConf | |
---|---|
void |
ThriftCLIService.init(HiveConf hiveConf)
|
Uses of HiveConf in org.apache.hive.service.server |
---|
Methods in org.apache.hive.service.server with parameters of type HiveConf | |
---|---|
void |
HiveServer2.init(HiveConf hiveConf)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |