Uses of Class
org.apache.hadoop.hive.conf.HiveConf

Packages that use HiveConf
org.apache.hadoop.hive.cli   
org.apache.hadoop.hive.conf   
org.apache.hadoop.hive.jdbc   
org.apache.hadoop.hive.metastore   
org.apache.hadoop.hive.ql   
org.apache.hadoop.hive.ql.exec Hive QL execution tasks, operators, functions and other handlers. 
org.apache.hadoop.hive.ql.hooks   
org.apache.hadoop.hive.ql.io   
org.apache.hadoop.hive.ql.lockmgr Hive Lock Manager interfaces and some custom implmentations 
org.apache.hadoop.hive.ql.lockmgr.zookeeper   
org.apache.hadoop.hive.ql.metadata   
org.apache.hadoop.hive.ql.optimizer   
org.apache.hadoop.hive.ql.optimizer.physical   
org.apache.hadoop.hive.ql.optimizer.ppr   
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.plan   
org.apache.hadoop.hive.ql.processors   
org.apache.hadoop.hive.ql.session   
 

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.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
JdbcSessionState(HiveConf conf)
           
 

Uses of HiveConf in org.apache.hadoop.hive.metastore
 

Fields in org.apache.hadoop.hive.metastore declared as 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 void MetaStoreUtils.makeDir(org.apache.hadoop.fs.Path path, HiveConf hiveConf)
           
static void TestHiveMetaStore.partitionTester(HiveMetaStoreClient client, HiveConf hiveConf)
           
 

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)
           
 

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)
          Given a Hive Configuration object - generate a command line fragment for passing such configuration information to ExecDriver.
static
<T extends Serializable>
Task<T>
TaskFactory.get(Class<T> workClass, HiveConf conf)
           
static
<T extends Serializable>
Task<T>
TaskFactory.get(T work, HiveConf conf, Task<? extends Serializable>... tasklist)
           
static
<T extends Serializable>
Task<T>
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)
           
static String MapRedTask.isEligibleForLocalMode(HiveConf conf, org.apache.hadoop.fs.ContentSummary inputSummary, int numReducers)
          Find out if a job can be run in local mode based on it's characteristics
 

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)
           
 

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.
 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.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
 

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
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)
           
static AbstractSemanticAnalyzerHook HiveUtils.getSemanticAnalyzerHook(HiveConf conf, String hookName)
           
 

Uses of HiveConf in org.apache.hadoop.hive.ql.optimizer
 

Methods in org.apache.hadoop.hive.ql.optimizer that return HiveConf
 HiveConf GenMRProcContext.getConf()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type HiveConf
static MapredWork GenMapRedUtils.getMapRedWork(HiveConf conf)
          create a new plan and return.
 void Optimizer.initialize(HiveConf hiveConf)
          Create the list of transformations.
 void GenMRProcContext.setConf(HiveConf conf)
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer with parameters of type HiveConf
GenMRProcContext(HiveConf conf, HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> opTaskMap, List<Operator<? extends Serializable>> seenOps, ParseContext parseCtx, List<Task<? extends Serializable>> mvTask, List<Task<? extends Serializable>> rootTasks, LinkedHashMap<Operator<? extends Serializable>,GenMRProcContext.GenMapRedCtx> mapCurrCtx, Set<ReadEntity> inputs, Set<WriteEntity> outputs)
           
 

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)
           
 void ParseContext.setConf(HiveConf conf)
           
 String VariableSubstitution.substitute(HiveConf conf, String expr)
           
 

Constructors in org.apache.hadoop.hive.ql.parse with parameters of type HiveConf
BaseSemanticAnalyzer.tableSpec(Hive db, HiveConf conf, ASTNode ast)
           
BaseSemanticAnalyzer(HiveConf conf)
           
DDLSemanticAnalyzer(HiveConf conf)
           
ExplainSemanticAnalyzer(HiveConf conf)
           
FunctionSemanticAnalyzer(HiveConf conf)
           
LoadSemanticAnalyzer(HiveConf conf)
           
ParseContext(HiveConf conf, QB qb, ASTNode ast, HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner, HashMap<TableScanOperator,PrunedPartitionList> opToPartList, HashMap<String,Operator<? extends Serializable>> topOps, HashMap<String,Operator<? extends Serializable>> topSelOps, LinkedHashMap<Operator<? extends Serializable>,OpParseContext> opParseCtx, Map<JoinOperator,QBJoinTree> joinContext, HashMap<TableScanOperator,Table> topToTable, List<LoadTableDesc> loadTableWork, List<LoadFileDesc> loadFileWork, Context ctx, HashMap<String,String> idToTableNameMap, int destTableId, UnionProcContext uCtx, List<AbstractMapJoinOperator<? extends MapJoinDesc>> listMapJoinOpsNoReducer, Map<GroupByOperator,Set<String>> groupOpToInputTables, Map<String,PrunedPartitionList> prunedPartitions, HashMap<TableScanOperator,FilterDesc.sampleDesc> opToSamplePruner)
           
SemanticAnalyzer(HiveConf conf)
           
 

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.
 

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)
           
 



Copyright © 2011 The Apache Software Foundation