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

Packages that use HiveConf
org.apache.hadoop.hive.cli   
org.apache.hadoop.hive.common   
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.exec.mr   
org.apache.hadoop.hive.ql.hooks   
org.apache.hadoop.hive.ql.index   
org.apache.hadoop.hive.ql.index.bitmap   
org.apache.hadoop.hive.ql.index.compact   
org.apache.hadoop.hive.ql.io   
org.apache.hadoop.hive.ql.io.orc The Optimized Row Columnar (ORC) File Format. 
org.apache.hadoop.hive.ql.io.rcfile.merge   
org.apache.hadoop.hive.ql.io.rcfile.stats   
org.apache.hadoop.hive.ql.io.rcfile.truncate   
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.metadata.formatting   
org.apache.hadoop.hive.ql.optimizer   
org.apache.hadoop.hive.ql.optimizer.index   
org.apache.hadoop.hive.ql.optimizer.physical   
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.plan   
org.apache.hadoop.hive.ql.processors   
org.apache.hadoop.hive.ql.security   
org.apache.hadoop.hive.ql.session   
org.apache.hadoop.hive.ql.udf.ptf   
org.apache.hadoop.hive.service   
org.apache.hive.beeline   
org.apache.hive.beeline.util   
org.apache.hive.service   
org.apache.hive.service.auth   
org.apache.hive.service.cli   
org.apache.hive.service.cli.operation   
org.apache.hive.service.cli.session   
org.apache.hive.service.cli.thrift   
org.apache.hive.service.server   
 

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 static HiveConf TestHiveMetaStore.hiveConf
           
protected  HiveConf TestMetastoreVersion.hiveConf
           
protected  HiveConf TestMarkPartition.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 Map<String,String> MetaStoreUtils.getMetaStoreSaslProperties(HiveConf conf)
          Read and return the meta store Sasl configuration.
static RawStore RetryingRawStore.getProxy(HiveConf hiveConf, 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(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)
           
MetaStoreSchemaInfo(String hiveHome, HiveConf hiveConf, String dbType)
           
RetryingHMSHandler(HiveConf hiveConf, String name)
           
RetryingMetaStoreClient(HiveConf hiveConf, HiveMetaHookLoader hookLoader, Class<? extends IMetaStoreClient> msClientClass)
           
RetryingRawStore(HiveConf hiveConf, 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 PTFPartition PTFPartition.create(HiveConf cfg, SerDe serDe, StructObjectInspector inputOI, StructObjectInspector outputOI)
           
 PTFPartition PTFOperator.createFirstPartitionForChain(ObjectInspector oi, HiveConf hiveConf, boolean isMapSide)
          Create a new Partition.
static org.apache.hadoop.hive.ql.exec.PartitionKeySampler.FetchSampler PartitionKeySampler.createSampler(FetchWork work, HiveConf conf, JobConf job, Operator<?> operator)
           
static int Utilities.estimateNumberOfReducers(HiveConf conf, ContentSummary inputSummary, MapWork work, boolean finalMapRed)
          Estimate the number of reducers needed for this job, based on job input, and configuration parameters.
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 DDLTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext ctx)
           
 void FunctionTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext ctx)
           
 void FetchTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext ctx)
           
 void ConditionalTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
           
 void Task.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
           
 void ColumnStatsTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext ctx)
           
protected  void PTFOperator.reconstructQueryDef(HiveConf hiveConf)
          Initialize the visitor to use the QueryDefDeserializer Use the order defined in QueryDefWalker to visit the QueryDef
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.
PTFPartition(HiveConf cfg, SerDe serDe, StructObjectInspector inputOI, StructObjectInspector outputOI)
           
SecureCmdDoAs(HiveConf conf)
           
 

Uses of HiveConf in org.apache.hadoop.hive.ql.exec.mr
 

Methods in org.apache.hadoop.hive.ql.exec.mr 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.
 void MapredLocalTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
           
 void ExecDriver.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
          Initialization when invoked from QL.
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
 

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
static
<T extends Hook>
List<T>
HookUtils.getHooks(HiveConf conf, HiveConf.ConfVars hookConfVar, Class<T> clazz)
          Returns the hooks specified in a configuration variable.
 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,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(FileSystem fs, HiveConf conf, Class<? extends InputFormat> inputFormatCls, ArrayList<FileStatus> files)
          checks if files are in same format as the given input format.
 void ReworkMapredInputFormat.rework(HiveConf job, MapredWork work)
           
 void SymbolicInputFormat.rework(HiveConf job, MapredWork work)
           
 boolean InputFormatChecker.validateInput(FileSystem fs, HiveConf conf, ArrayList<FileStatus> files)
          This method is used to validate the input files.
 boolean RCFileInputFormat.validateInput(FileSystem fs, HiveConf conf, ArrayList<FileStatus> files)
           
 boolean SequenceFileInputFormatChecker.validateInput(FileSystem fs, HiveConf conf, ArrayList<FileStatus> files)
           
 

Uses of HiveConf in org.apache.hadoop.hive.ql.io.orc
 

Methods in org.apache.hadoop.hive.ql.io.orc with parameters of type HiveConf
 boolean OrcInputFormat.validateInput(FileSystem fs, HiveConf conf, ArrayList<FileStatus> 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.resolveConcatenateMerge(HiveConf conf)
          alter table ...
 void MergeWork.resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf conf, Path path, TableDesc tblDesc, ArrayList<String> aliases, PartitionDesc partDesc)
           
 

Uses of HiveConf in org.apache.hadoop.hive.ql.io.rcfile.stats
 

Methods in org.apache.hadoop.hive.ql.io.rcfile.stats with parameters of type HiveConf
 void PartialScanTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
           
 

Uses of HiveConf in org.apache.hadoop.hive.ql.io.rcfile.truncate
 

Methods in org.apache.hadoop.hive.ql.io.rcfile.truncate with parameters of type HiveConf
 void ColumnTruncateTask.initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
           
 

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
 List<HiveLock> EmbeddedLockManager.getLocks(boolean verifyTablePartitions, boolean fetchData, HiveConf conf)
           
 List<HiveLock> EmbeddedLockManager.getLocks(HiveLockObject key, boolean verifyTablePartitions, boolean fetchData, HiveConf conf)
           
 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, Path srcf, Path destf, 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 boolean Hive.renameFile(HiveConf conf, Path srcf, Path destf, FileSystem fs, boolean replace)
           
protected static void Hive.replaceFiles(Path srcf, Path destf, 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
static MetaDataFormatter MetaDataFormatUtils.getFormatter(HiveConf conf)
           
 void JsonMetaDataFormatter.showTableStatus(DataOutputStream out, 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.
 

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

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

Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type HiveConf
protected  void GroupByOptimizer.SortGroupByProcessor.convertGroupByMapSideSortedGroupBy(HiveConf conf, GroupByOperator groupByOp, int depth)
           
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.
protected  long SizeBasedBigTableSelectorForAutoSMJ.getSize(HiveConf conf, Partition partition)
           
protected  long SizeBasedBigTableSelectorForAutoSMJ.getSize(HiveConf conf, Table table)
           
 void Optimizer.initialize(HiveConf hiveConf)
          Create the list of transformations.
 void GenMRProcContext.setConf(HiveConf conf)
           
 void GroupByOptimizer.GroupByOptimizerContext.setConf(HiveConf conf)
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer with parameters of type HiveConf
BucketJoinProcCtx(HiveConf conf)
           
GenMRProcContext(HiveConf conf, HashMap<Operator<? extends OperatorDesc>,Task<? extends Serializable>> opTaskMap, 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)
           
SortBucketJoinProcCtx(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.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
protected  ListBucketingCtx BaseSemanticAnalyzer.constructListBucketingCtx(List<String> skewedColNames, List<List<String>> skewedValues, Map<List<String>,String> skewedColValueLocationMaps, boolean isStoredAsSubDirectories, HiveConf conf)
          Construct list bucketing context.
static BaseSemanticAnalyzer SemanticAnalyzerFactory.get(HiveConf conf, ASTNode tree)
           
 void MapReduceCompiler.init(HiveConf conf, SessionState.LogHelper console, Hive db)
           
 WindowingSpec WindowingComponentizer.next(HiveConf hCfg, SemanticAnalyzer semAly, org.apache.hadoop.hive.ql.parse.UnparseTranslator unparseT, RowResolver inputRR)
           
static String EximUtil.relativeToAbsolutePath(HiveConf conf, String location)
           
 void ParseContext.setConf(HiveConf conf)
           
 String VariableSubstitution.substitute(HiveConf conf, String expr)
           
 PTFDesc PTFTranslator.translate(PTFInvocationSpec qSpec, SemanticAnalyzer semAly, HiveConf hCfg, RowResolver inputRR, org.apache.hadoop.hive.ql.parse.UnparseTranslator unparseT)
           
 PTFDesc PTFTranslator.translate(WindowingSpec wdwSpec, SemanticAnalyzer semAly, HiveConf hCfg, RowResolver inputRR, org.apache.hadoop.hive.ql.parse.UnparseTranslator unparseT)
           
static void BaseSemanticAnalyzer.validatePartSpec(Table tbl, Map<String,String> partSpec, ASTNode astNode, HiveConf conf)
           
 

Constructors in org.apache.hadoop.hive.ql.parse with parameters of type HiveConf
BaseSemanticAnalyzer.tableSpec(Hive db, HiveConf conf, ASTNode ast)
           
BaseSemanticAnalyzer.tableSpec(Hive db, HiveConf conf, ASTNode ast, boolean allowDynamicPartitionsSpec, boolean allowPartialPartitionsSpec)
           
BaseSemanticAnalyzer(HiveConf conf)
           
ColumnStatsSemanticAnalyzer(HiveConf conf)
           
ColumnStatsSemanticAnalyzer(HiveConf conf, ASTNode tree)
           
DDLSemanticAnalyzer(HiveConf conf)
           
ExplainSemanticAnalyzer(HiveConf conf)
           
ExportSemanticAnalyzer(HiveConf conf)
           
FunctionSemanticAnalyzer(HiveConf conf)
           
ImportSemanticAnalyzer(HiveConf conf)
           
LoadSemanticAnalyzer(HiveConf conf)
           
MacroSemanticAnalyzer(HiveConf conf)
           
ParseContext(HiveConf conf, QB qb, ASTNode ast, HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner, HashMap<TableScanOperator,PrunedPartitionList> opToPartList, HashMap<String,Operator<? extends OperatorDesc>> topOps, HashMap<String,Operator<? extends OperatorDesc>> topSelOps, LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx, Map<JoinOperator,QBJoinTree> joinContext, Map<SMBMapJoinOperator,QBJoinTree> smbMapJoinContext, HashMap<TableScanOperator,Table> topToTable, HashMap<TableScanOperator,Map<String,String>> topToProps, Map<FileSinkOperator,Table> fsopToTable, 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, GlobalLimitCtx globalLimitCtx, HashMap<String,SplitSample> nameToSplitSample, HashSet<ReadEntity> semanticInputs, List<Task<? extends Serializable>> rootTasks, Map<TableScanOperator,Map<String,ExprNodeDesc>> opToPartToSkewedPruner, Map<String,ReadEntity> viewAliasToInput, List<ReduceSinkOperator> reduceSinkOperatorsAddedByEnforceBucketingSorting, QueryProperties queryProperties)
           
SemanticAnalyzer(HiveConf conf)
           
 

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

Methods in org.apache.hadoop.hive.ql.plan that return HiveConf
 HiveConf PTFDesc.getCfg()
           
 

Methods in org.apache.hadoop.hive.ql.plan with parameters of type HiveConf
 List<Task<? extends Serializable>> ConditionalResolverMergeFiles.getTasks(HiveConf conf, Object objCtx)
           
 List<Task<? extends Serializable>> ConditionalResolver.getTasks(HiveConf conf, Object ctx)
          All conditional resolvers implement this interface.
 List<Task<? extends Serializable>> ConditionalResolverCommonJoin.getTasks(HiveConf conf, Object objCtx)
           
 List<Task<? extends Serializable>> ConditionalResolverSkewJoin.getTasks(HiveConf conf, Object objCtx)
           
 void MapWork.resolveDynamicPartitionStoredAsSubDirsMerge(HiveConf conf, Path path, TableDesc tblDesc, ArrayList<String> aliases, PartitionDesc partDesc)
           
 void PTFDesc.setCfg(HiveConf cfg)
           
 

Constructors in org.apache.hadoop.hive.ql.plan with parameters of type HiveConf
PTFDeserializer(PTFDesc ptfDesc, StructObjectInspector inputOI, HiveConf hConf)
           
 

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

Fields in org.apache.hadoop.hive.ql.security declared as HiveConf
protected  HiveConf TestMetastoreAuthorizationProvider.clientHiveConf
           
protected  HiveConf TestClientSideAuthorizationProvider.clientHiveConf
           
 

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.ql.udf.ptf
 

Methods in org.apache.hadoop.hive.ql.udf.ptf with parameters of type HiveConf
 void TableFunctionResolver.initialize(HiveConf cfg, PTFDesc ptfDesc, PTFDesc.PartitionedTableFunctionDef tDef)
           
 

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

Methods in org.apache.hive.beeline that return HiveConf
 HiveConf HiveSchemaTool.getHiveConf()
           
 

Constructors in org.apache.hive.beeline with parameters of type HiveConf
HiveSchemaTool(String hiveHome, HiveConf hiveConf, String dbType)
           
 

Uses of HiveConf in org.apache.hive.beeline.util
 

Constructors in org.apache.hive.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.auth
 

Methods in org.apache.hive.service.auth with parameters of type HiveConf
static void HiveAuthFactory.loginFromKeytab(HiveConf hiveConf)
           
 

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 HiveSessionImpl.getHiveConf()
           
 HiveConf HiveSession.getHiveConf()
           
 HiveConf HiveSessionHookContextImpl.getSessionConf()
           
 HiveConf HiveSessionHookContext.getSessionConf()
          Retrieve session conf
 

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
 

Fields in org.apache.hive.service.cli.thrift declared as HiveConf
protected static HiveConf ThriftCLIServiceTest.hiveConf
           
protected  HiveConf ThriftCLIService.hiveConf
           
 

Methods in org.apache.hive.service.cli.thrift with parameters of type HiveConf
 void ThriftCLIService.init(HiveConf hiveConf)
           
protected static void ThriftCLIServiceTest.startHiveServer2WithConf(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)
           
 



Copyright © 2012 The Apache Software Foundation