A B C D E F G H I J K L M N O P Q R S T U V W X Z

A

abort(WriterContext) - Method in class HCatWriter
This method should be called at master node.
abort(WriterContext) - Method in class HCatOutputFormatWriter
 
abortJob(JobContext, JobStatus.State) - Method in class MultiOutputFormat.MultiOutputCommitter
 
abortJob(OutputFormat, Job) - Method in interface HCatHadoopShims
 
abortTask(TaskAttemptContext) - Method in class MultiOutputFormat.MultiOutputCommitter
 
abortWriteTransaction(Transaction) - Method in interface RevisionManager
Abort the write transaction.
abortWriteTransaction(Transaction) - Method in class RevisionManagerEndpoint
 
abortWriteTransaction(Transaction) - Method in class RevisionManagerEndpointClient
 
abortWriteTransaction(Transaction) - Method in class ZKBasedRevisionManager
This method aborts a write transaction.
addArgs(List<String>) - Method in class SecureProxySupport
Add hcat args.
addCacheFiles(List<String>, AppConfig) - Static method in class LauncherDelegator
Add files to the Distributed Cache for the controller job.
addChild(String) - Method in class JobState
Add a jobid to the list of children of this job.
addDef(List<String>, String, String) - Static method in class LauncherDelegator
Add a Hadoop command line definition to args if the value is not null.
addEnv(Map<String, String>) - Method in class SecureProxySupport
Add Hadoop env variables.
addField(FieldSchema) - Method in class HCatSchemaUtils.CollectionBuilder
 
addField(HCatFieldSchema) - Method in class HCatSchemaUtils.CollectionBuilder
 
addOneColumn(String, String, String, ColumnDesc) - Method in class HcatDelegator
Add one column.
addOneColumn(String, String, String, ColumnDesc) - Method in class Server
Create a column in an hcat table.
addOnePartition(String, String, String, PartitionDesc) - Method in class HcatDelegator
Add one partition.
addOnePartition(String, String, String, PartitionDesc) - Method in class Server
Create a partition in an hcat table.
addOneTableProperty(String, String, String, TablePropertyDesc) - Method in class HcatDelegator
Add one table property.
addOneTableProperty(String, String, String, TablePropertyDesc) - Method in class Server
Add a single property on an hcat table.
addOutputFormat(String, Class<? extends OutputFormat>, Class<?>, Class<?>) - Method in class MultiOutputFormat.JobConfigurer
Add a OutputFormat configuration to the Job with a alias name.
addPartition(HCatAddPartitionDesc) - Method in class HCatClient
Adds the partition.
addPartition(HCatAddPartitionDesc) - Method in class HCatClientHMSImpl
 
addPartitions(List<HCatAddPartitionDesc>) - Method in class HCatClient
Adds a list of partitions.
addPartitions(List<HCatAddPartitionDesc>) - Method in class HCatClientHMSImpl
 
addRedirects(Server) - Method in class Main
 
addResources(Configuration) - Static method in class RevisionManagerConfiguration
 
addToRevisionList(StoreFamilyRevision) - Method in class StoreFamilyRevisionList
 
appConf - Variable in class TempletonDelegator
 
appConf - Variable in class HDFSCleanup
 
appConf - Variable in class ZooKeeperCleanup
 
AppConfig - Class in org.apache.hcatalog.templeton
The configuration for Templeton.
AppConfig() - Constructor for class AppConfig
 
append(HCatFieldSchema) - Method in class HCatSchema
 
appendCauseMessage() - Method in enum ErrorType
Whether the cause of the exception should be added to the error message.
authorize(Privilege[], Privilege[]) - Method in class HCatSemanticAnalyzerBase
 
authorize(Database, Privilege) - Method in class HCatSemanticAnalyzerBase
 
authorize(Table, Privilege) - Method in class HCatSemanticAnalyzerBase
 
authorize(Partition, Privilege) - Method in class HCatSemanticAnalyzerBase
 
authorize(Privilege[], Privilege[]) - Method in class HdfsAuthorizationProvider
 
authorize(Database, Privilege[], Privilege[]) - Method in class HdfsAuthorizationProvider
 
authorize(Table, Privilege[], Privilege[]) - Method in class HdfsAuthorizationProvider
 
authorize(Table, Partition, Privilege[], Privilege[]) - Method in class HdfsAuthorizationProvider
 
authorize(Partition, Privilege[], Privilege[]) - Method in class HdfsAuthorizationProvider
 
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in class HdfsAuthorizationProvider
 
authorize(Path, Privilege[], Privilege[]) - Method in class HdfsAuthorizationProvider
Authorization privileges against a path.
authorize(Privilege[], Privilege[]) - Method in class StorageDelegationAuthorizationProvider
 
authorize(Database, Privilege[], Privilege[]) - Method in class StorageDelegationAuthorizationProvider
 
authorize(Table, Privilege[], Privilege[]) - Method in class StorageDelegationAuthorizationProvider
 
authorize(Partition, Privilege[], Privilege[]) - Method in class StorageDelegationAuthorizationProvider
 
authorize(Table, Partition, List<String>, Privilege[], Privilege[]) - Method in class StorageDelegationAuthorizationProvider
 
authorizeDDL(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class HCatSemanticAnalyzerBase
Checks for the given rootTasks, and calls authorizeDDLWork() for each DDLWork to be authorized.
authorizeDDLWork(HiveSemanticAnalyzerHookContext, Hive, DDLWork) - Method in class HCatSemanticAnalyzer
 
authorizeDDLWork(HiveSemanticAnalyzerHookContext, Hive, DDLWork) - Method in class HCatSemanticAnalyzerBase
Authorized the given DDLWork.
authorizeTable(Hive, String, Privilege) - Method in class HCatSemanticAnalyzerBase
 
authProviders - Static variable in class StorageDelegationAuthorizationProvider
 

B

BadParam - Class in org.apache.hcatalog.templeton
Missing required or badly configured paramater.
BadParam(String) - Constructor for class BadParam
 
beginWriteTransaction(String, List<String>) - Method in interface RevisionManager
Start the write transaction.
beginWriteTransaction(String, List<String>, long) - Method in interface RevisionManager
Start the write transaction.
beginWriteTransaction(String, List<String>) - Method in class RevisionManagerEndpoint
 
beginWriteTransaction(String, List<String>, long) - Method in class RevisionManagerEndpoint
 
beginWriteTransaction(String, List<String>) - Method in class RevisionManagerEndpointClient
 
beginWriteTransaction(String, List<String>, long) - Method in class RevisionManagerEndpointClient
 
beginWriteTransaction(String, List<String>, long) - Method in class ZKBasedRevisionManager
 
beginWriteTransaction(String, List<String>) - Method in class ZKBasedRevisionManager
 
BINARY - Static variable in class DataType
 
BOOLEAN - Static variable in class DataType
 
bucketCols(List<String>, int) - Method in class HCatCreateTableDesc.Builder
Bucket cols.
build() - Method in class HCatAddPartitionDesc.Builder
Builds the HCatAddPartitionDesc.
build() - Method in class HCatCreateDBDesc.Builder
Builds the create database descriptor.
build() - Method in class HCatCreateTableDesc.Builder
Builds the HCatCreateTableDesc.
build() - Method in class HCatSchemaUtils.CollectionBuilder
 
build() - Method in class HCatSchemaUtils.HCatSchemaBuilder
 
build() - Method in class HCatSchemaUtils.MapBuilder
 
build() - Method in class ReadEntity.Builder
 
build() - Method in class WriteEntity.Builder
 
build() - Method in class JsonBuilder
Turn the map back to response object.
buildErrorMessage(ErrorType, String, Throwable) - Static method in exception HCatException
Builds the error message string.
buildJson() - Method in class JsonBuilder
Turn the map back to json.
buildMessage(int, Map<String, Object>, String) - Static method in class SimpleWebException
 
buildResponse() - Method in class JsonBuilder
Turn the map back to response object.
buildResponse(int) - Method in class JsonBuilder
Turn the map back to response object.
BusyException - Class in org.apache.hcatalog.templeton
Simple "we are busy, try again" exception.
BusyException() - Constructor for class BusyException
 
BYTE - Static variable in class DataType
 

C

callback - Variable in class QueueStatusBean
 
CALLBACK_INTERVAL_NAME - Static variable in class AppConfig
 
CALLBACK_RETRY_NAME - Static variable in class AppConfig
 
CallbackFailedException - Class in org.apache.hcatalog.templeton
The callback failed when it tried to reach the callback URL.
CallbackFailedException(String) - Constructor for class CallbackFailedException
 
cancelDelegationToken(String) - Method in class HCatClient
Cancel delegation token.
cancelDelegationToken(String) - Method in class HCatClientHMSImpl
 
CatchallExceptionMapper - Class in org.apache.hcatalog.templeton
Map all exceptions to the Jersey response.
CatchallExceptionMapper() - Constructor for class CatchallExceptionMapper
 
checkAndDelete(String, ZooKeeper) - Method in class ZooKeeperCleanup
Check to see if a job is more than maxage old, and delete it if so.
checkJobContextIfRunningFromBackend(JobContext) - Static method in class HCatUtil
 
checkOutputSpecs(FileSystem, JobConf) - Method in class HBaseBaseOutputFormat
 
checkOutputSpecs(JobContext) - Method in class HCatBaseOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(JobContext) - Method in class MultiOutputFormat
 
checkPermissions(Configuration, Path, EnumSet<FsAction>) - Static method in class HdfsAuthorizationProvider
Checks the permissions for the given path and current user on Hadoop FS.
checkPermissions(FileSystem, Path, EnumSet<FsAction>, String, String[]) - Static method in class HdfsAuthorizationProvider
Checks the permissions for the given path and current user on Hadoop FS.
className - Variable in class TableDesc.StoredByDesc
 
cleanupOnFailure(String, Job) - Method in class HCatStorer
 
clear() - Method in class StoreFamilyRevision
 
clear() - Method in class StoreFamilyRevisionList
 
close() - Method in class TempletonJobTracker
Close the connection to the Job Tracker.
close() - Method in class HCatClient
Close the hcatalog client.
close() - Method in class HCatClientHMSImpl
 
close() - Method in interface RevisionManager
Closes the revision manager.
close() - Method in class RevisionManagerEndpoint
 
close() - Method in class RevisionManagerEndpointClient
 
close() - Method in class ZKBasedRevisionManager
Close Zookeeper connection
close() - Method in class RCFileMapReduceRecordReader
 
close() - Method in class SecureProxySupport
Cleanup
close() - Method in class JobState
For storage methods that require a connection, this is a hint that it's time to close the connection.
close() - Method in class NullRecordReader
 
close() - Method in class ZooKeeperStorage
Close this ZK connection.
closeHiveClientQuietly(HiveMetaStoreClient) - Static method in class HCatUtil
 
closeStorage() - Method in class HDFSStorage
 
closeStorage() - Method in interface TempletonStorage
For storage methods that require a connection, this is a hint that it's time to close the connection.
closeStorage() - Method in class ZooKeeperStorage
 
clusteredBy - Variable in class TableDesc
 
clusterHadoop() - Method in class AppConfig
 
clusterHcat() - Method in class AppConfig
 
collectionItemsTerminatedBy - Variable in class TableDesc.RowFormatDesc
 
ColumnDesc - Class in org.apache.hcatalog.templeton
A description of the column to create.
ColumnDesc() - Constructor for class ColumnDesc
 
ColumnDesc(String, String, String) - Constructor for class ColumnDesc
Create a new ColumnDesc
columnName - Variable in class TableDesc.ClusterSortOrderDesc
 
columnNames - Variable in class TableDesc.ClusteredByDesc
 
columns - Variable in class TableDesc
 
comment(String) - Method in class HCatCreateDBDesc.Builder
Comment.
comment - Variable in class ColumnDesc
 
comment - Variable in class DatabaseDesc
 
comment - Variable in class TableDesc
 
comments(String) - Method in class HCatCreateTableDesc.Builder
Comments.
commit(WriterContext) - Method in class HCatWriter
This method should be called at master node.
commit(WriterContext) - Method in class HCatOutputFormatWriter
 
commitCreateTable(Table) - Method in class HBaseHCatStorageHandler
 
commitDropTable(Table, boolean) - Method in class HBaseHCatStorageHandler
 
commitJob(JobContext) - Method in class MultiOutputFormat.MultiOutputCommitter
 
commitJob(OutputFormat, Job) - Method in interface HCatHadoopShims
 
commitTask(TaskAttemptContext) - Method in class MultiOutputFormat.MultiOutputCommitter
 
commitWriteTransaction(Transaction) - Method in interface RevisionManager
Commit the write transaction.
commitWriteTransaction(Transaction) - Method in class RevisionManagerEndpoint
 
commitWriteTransaction(Transaction) - Method in class RevisionManagerEndpointClient
 
commitWriteTransaction(Transaction) - Method in class ZKBasedRevisionManager
This method commits a write transaction.
compare(Object, Object) - Static method in class DataType
 
compare(Object, Object, byte, byte) - Static method in class DataType
 
compareTo(FamilyRevision) - Method in class FamilyRevision
 
compareTo(ZNodeName) - Method in class ZNodeName
 
compareTo(StoreFamilyRevision) - Method in class StoreFamilyRevision
 
compareTo(StoreFamilyRevisionList) - Method in class StoreFamilyRevisionList
 
CompleteBean - Class in org.apache.hcatalog.templeton
CompleteBean - The results of an CompleteDelegator run.
CompleteBean() - Constructor for class CompleteBean
 
CompleteBean(String) - Constructor for class CompleteBean
Create a new CompleteBean
completed - Variable in class QueueStatusBean
 
CompleteDelegator - Class in org.apache.hcatalog.templeton
Complete a job.
CompleteDelegator(AppConfig) - Constructor for class CompleteDelegator
 
completeJob(String) - Method in class Server
Notify on a completed job.
conf - Variable in class HCatReader
 
conf - Variable in class HCatWriter
 
conf - Variable in class FosterStorageHandler
 
CONF_MAPREDUCE_JOB_CREDENTIALS_BINARY - Static variable in class HCatConstants
 
configure() - Method in class MultiOutputFormat.JobConfigurer
Configure the job with the multiple output formats added.
configure() - Method in class WadlConfig
 
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class HBaseHCatStorageHandler
 
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class FosterStorageHandler
 
configureInputJobProperties(TableDesc, Map<String, String>) - Method in class HCatStorageHandler
This method is called to allow the StorageHandlers the chance to populate the JobContext.getConfiguration() with properties that maybe be needed by the handler's bundled artifacts (ie InputFormat, SerDe, etc).
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in class HBaseHCatStorageHandler
 
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in class FosterStorageHandler
 
configureOutputJobProperties(TableDesc, Map<String, String>) - Method in class HCatStorageHandler
This method is called to allow the StorageHandlers the chance to populate the JobContext.getConfiguration() with properties that maybe be needed by the handler's bundled artifacts (ie InputFormat, SerDe, etc).
configureOutputStorageHandler(HCatStorageHandler, Configuration, OutputJobInfo) - Static method in class HCatUtil
 
configureOutputStorageHandler(JobContext, OutputJobInfo, Map<String, String>) - Static method in class HCatBaseOutputFormat
Configure the output storage handler, with allowing specification of partvals from which it picks the dynamic partvals
configureTableJobProperties(TableDesc, Map<String, String>) - Method in class HCatStorageHandler
Deprecated. 
conn - Variable in class NotificationListener
 
ConnectionFailureException - Exception in org.apache.hcatalog.api
Class representing exceptions resulting from connection problems between HCat client and server.
ConnectionFailureException(String, Throwable) - Constructor for exception ConnectionFailureException
 
controllerMRChildOpts() - Method in class AppConfig
 
copy(HCatRecord) - Method in class DefaultHCatRecord
 
copy(HCatRecord) - Method in class HCatRecord
 
copy(HCatRecord) - Method in class LazyHCatRecord
 
COPY_NAME - Static variable in class TempletonControllerJob
 
copyConf(Configuration, Configuration) - Static method in class HCatUtil
Replace the contents of dest with the contents of src
copyJobPropertiesToJobConf(Map<String, String>, JobConf) - Static method in class HCatUtil
 
create(String, String, String, Map<String, String>) - Static method in class HCatAddPartitionDesc
Creates the builder for specifying attributes.
create(Configuration) - Static method in class HCatClient
Creates an instance of HCatClient.
create(String) - Static method in class HCatCreateDBDesc
Creates the builder for defining attributes.
create(String, String, List<HCatFieldSchema>) - Static method in class HCatCreateTableDesc
Creates a builder for defining attributes.
create() - Static method in class RevisionManagerConfiguration
Creates a Configuration with Revision Manager resources
create(Configuration) - Static method in class RevisionManagerConfiguration
Creates a clone of passed configuration.
create(String, String, String, Properties) - Static method in class InputJobInfo
Initializes a new InputJobInfo for reading data from a table.
create(String, String, String) - Static method in class InputJobInfo
Deprecated. 
create(String, String, Map<String, String>) - Static method in class OutputJobInfo
Initializes a new OutputJobInfo instance for writing data from a table.
create(String) - Static method in class JsonBuilder
Create a new map object from the existing json.
create() - Static method in class JsonBuilder
Create a new map object.
create() - Method in class JobStateTracker
Create the parent znode for this job state.
create(TempletonStorage.Type, String) - Method in class ZooKeeperStorage
Create a node in ZooKeeper
createConfigurer(Job) - Static method in class MultiOutputFormat
Get a JobConfigurer instance that will support configuration of the job for multiple output formats.
createConnection() - Method in class NotificationListener
 
createDatabase(HCatCreateDBDesc) - Method in class HCatClient
Creates the database.
createDatabase(HCatCreateDBDesc) - Method in class HCatClientHMSImpl
 
createDatabase(String, DatabaseDesc) - Method in class HcatDelegator
Create a database with the given name
createDatabase(String, DatabaseDesc) - Method in class Server
Create a database
createError(String, int) - Static method in class JsonBuilder
Create a new map error object.
createJobContext(JobContext) - Static method in class HCatMapRedUtil
 
createJobContext(JobConf, JobID, Progressable) - Static method in class HCatMapRedUtil
 
createJobContext(Configuration, JobID) - Method in interface HCatHadoopShims
 
createJobContext(JobConf, JobID, Progressable) - Method in interface HCatHadoopShims
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class HCatBaseInputFormat
Create the RecordReader for the given InputSplit.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class RCFileMapReduceInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class SingleInputFormat
 
createSnapshot(String) - Method in interface RevisionManager
Create the latest snapshot of the table.
createSnapshot(String, long) - Method in interface RevisionManager
Create the snapshot of the table using the revision number.
createSnapshot(String) - Method in class RevisionManagerEndpoint
 
createSnapshot(String, long) - Method in class RevisionManagerEndpoint
 
createSnapshot(String) - Method in class RevisionManagerEndpointClient
 
createSnapshot(String, long) - Method in class RevisionManagerEndpointClient
 
createSnapshot(String) - Method in class ZKBasedRevisionManager
 
createSnapshot(String, long) - Method in class ZKBasedRevisionManager
 
createTable(HCatCreateTableDesc) - Method in class HCatClient
Creates the table.
createTable(HCatCreateTableDesc) - Method in class HCatClientHMSImpl
 
createTable(String, List<String>) - Method in interface RevisionManager
Setup revision management for a newly created hbase table.
createTable(String, List<String>) - Method in class RevisionManagerEndpoint
 
createTable(String, List<String>) - Method in class RevisionManagerEndpointClient
 
createTable(String, List<String>) - Method in class ZKBasedRevisionManager
 
createTable(String, String, TableDesc) - Method in class HcatDelegator
Create a table.
createTable(String, String, TableDesc) - Method in class Server
Create a new table.
createTableLike(String, String, String, boolean, boolean, String) - Method in class HCatClient
Creates the table like an existing table.
createTableLike(String, String, String, boolean, boolean, String) - Method in class HCatClientHMSImpl
 
createTableLike(String, String, TableLikeDesc) - Method in class HcatDelegator
Create a table like another.
createTableLike(String, String, String, TableLikeDesc) - Method in class Server
Create a new table like another table.
createTaskAttemptContext(TaskAttemptContext) - Static method in class HCatMapRedUtil
 
createTaskAttemptContext(Configuration, TaskAttemptID) - Static method in class HCatMapRedUtil
 
createTaskAttemptContext(JobConf, TaskAttemptID, Progressable) - Static method in class HCatMapRedUtil
 
createTaskAttemptContext(Configuration, TaskAttemptID) - Method in interface HCatHadoopShims
 
createTaskAttemptContext(JobConf, TaskAttemptID, Progressable) - Method in interface HCatHadoopShims
 
createTaskAttemptID() - Method in interface HCatHadoopShims
 
createTaskID() - Method in interface HCatHadoopShims
 

D

database - Variable in class DatabaseDesc
 
DatabaseDesc - Class in org.apache.hcatalog.templeton
A description of the database to create.
DatabaseDesc() - Constructor for class DatabaseDesc
 
databaseProperties(Map<String, String>) - Method in class HCatCreateDBDesc.Builder
Database properties.
DataTransferFactory - Class in org.apache.hcatalog.data.transfer
Use this factory to get instances of HCatReader or HCatWriter at master and slave nodes.
DataTransferFactory() - Constructor for class DataTransferFactory
 
DataType - Class in org.apache.hcatalog.data
 
DataType() - Constructor for class DataType
 
ddl(String, String, String) - Method in class Server
Execute an hcat ddl expression on the local box.
DDL_ID - Static variable in class Server
 
decodeArray(String) - Static method in class TempletonUtils
Take an encode strings and decode it into an array of strings.
decodeBytes(String) - Static method in class HCatUtil
 
deepCopy() - Method in class StoreFamilyRevision
 
deepCopy() - Method in class StoreFamilyRevisionList
 
DEFAULT_PORT - Static variable in class Main
 
DEFAULT_PREFIX - Static variable in class HBaseHCatStorageHandler
 
DefaultHCatRecord - Class in org.apache.hcatalog.data
 
DefaultHCatRecord() - Constructor for class DefaultHCatRecord
 
DefaultHCatRecord(int) - Constructor for class DefaultHCatRecord
 
DefaultHCatRecord(List<Object>) - Constructor for class DefaultHCatRecord
 
DefaultStateProvider - Class in org.apache.hcatalog.data.transfer.state
 
DefaultStateProvider() - Constructor for class DefaultStateProvider
 
delete(TempletonStorage.Type, String) - Method in class HDFSStorage
 
delete() - Method in class JobState
 
delete() - Method in class JobStateTracker
 
delete(TempletonStorage.Type, String) - Method in interface TempletonStorage
Delete a data grouping (all data for a jobid, all tracking data for a job, etc.).
delete(TempletonStorage.Type, String) - Method in class ZooKeeperStorage
 
DeleteDelegator - Class in org.apache.hcatalog.templeton
Delete a job
DeleteDelegator(AppConfig) - Constructor for class DeleteDelegator
 
deleteQueueId(String) - Method in class Server
Kill a job in the queue.
descColumn(String, String, String) - Method in class Server
Describe a single column in an hcat table.
descDatabase(String, String, boolean) - Method in class HcatDelegator
Return a json description of the database.
descDatabase(String, String) - Method in class Server
Describe a database
descExtendedTable(String, String, String) - Method in class HcatDelegator
Return a json "show table extended like".
descOneColumn(String, String, String, String) - Method in class HcatDelegator
Return a json description of one column.
descOnePartition(String, String, String, String) - Method in class HcatDelegator
Return a json description of one partition.
descOneTableProperty(String, String, String) - Method in class Server
Describe a single property on an hcat table.
descPartition(String, String, String) - Method in class Server
Describe a single partition in an hcat table.
descTable(String, String, String, boolean) - Method in class HcatDelegator
Return a json description of the table.
descTable(String, String, String) - Method in class Server
Describe an hcat table.
descTableProperty(String, String, String, String) - Method in class HcatDelegator
Describe one table property.
deserialize(String) - Static method in class HCatUtil
 
deserialize(Writable) - Method in class HCatRecordSerDe
The purpose of a deserialize method is to turn a data blob which is a writable representation of the data into an object that can then be parsed using the appropriate ObjectInspector.
deserialize(Writable) - Method in class JsonSerDe
Takes JSON string in Text form, and has to return an object representation above it that's readable by the corresponding object inspector.
doCallback(String, String) - Static method in class CompleteDelegator
Call the callback url with the jobid to let them know it's finished.
DOUBLE - Static variable in class DataType
 
dropDatabase(String, boolean, HCatClient.DropDBMode) - Method in class HCatClient
Drops a database.
dropDatabase(String, boolean, HCatClient.DropDBMode) - Method in class HCatClientHMSImpl
 
dropDatabase(String, String, boolean, String, String, String) - Method in class HcatDelegator
Drop the given database
dropDatabase(String, boolean, String, String, String) - Method in class Server
Drop a database
dropPartition(String, String, String, String, boolean, String, String) - Method in class HcatDelegator
Drop a partition.
dropPartition(String, String, String, boolean, String, String) - Method in class Server
Drop a partition in an hcat table.
dropPartitions(String, String, Map<String, String>, boolean) - Method in class HCatClient
Drops partition(s) that match the specified (and possibly partial) partition specification.
dropPartitions(String, String, Map<String, String>, boolean) - Method in class HCatClientHMSImpl
 
dropTable(String, String, boolean) - Method in class HCatClient
Drop table.
dropTable(String, String, boolean) - Method in class HCatClientHMSImpl
 
dropTable(String) - Method in interface RevisionManager
Remove table data from revision manager for a dropped table.
dropTable(String) - Method in class RevisionManagerEndpoint
 
dropTable(String) - Method in class RevisionManagerEndpointClient
 
dropTable(String) - Method in class ZKBasedRevisionManager
 
dropTable(String, String, String, boolean, String, String) - Method in class HcatDelegator
Drop a table.
dropTable(String, String, boolean, String, String) - Method in class Server
Drop an hcat table.
DYNTEMP_DIR_NAME - Static variable in class FosterStorageHandler
The directory under which data is initially written for a partitioned table

E

encodeArray(String[]) - Static method in class TempletonUtils
Take an array of strings and encode it into one string.
encodeArray(List<String>) - Static method in class TempletonUtils
Encode a List into a string.
encodeBytes(byte[]) - Static method in class HCatUtil
 
ENCODING - Static variable in class ZooKeeperStorage
 
EnqueueBean - Class in org.apache.hcatalog.templeton
EnqueueBean - The results of a call that enqueues a Hadoop job.
EnqueueBean() - Constructor for class EnqueueBean
 
EnqueueBean(String) - Constructor for class EnqueueBean
Create a new EnqueueBean.
enqueueController(String, String, List<String>) - Method in class LauncherDelegator
Enqueue the TempletonControllerJob directly calling doAs.
equals(Object) - Method in class Pair
 
equals(Object) - Method in class HCatFieldSchema
 
equals(Object) - Method in class HCatSchema
 
equals(Object) - Method in class ZNodeName
 
equals(Object) - Method in class StoreFamilyRevision
 
equals(StoreFamilyRevision) - Method in class StoreFamilyRevision
 
equals(Object) - Method in class StoreFamilyRevisionList
 
equals(StoreFamilyRevisionList) - Method in class StoreFamilyRevisionList
 
equals(Object) - Method in class HCatTableInfo
 
equals(Object) - Method in class ColumnDesc
 
equals(Object) - Method in class GroupPermissionsDesc
 
equals(Object) - Method in class TableDesc.ClusteredByDesc
 
equals(Object) - Method in class TableDesc.ClusterSortOrderDesc
 
equals(Object) - Method in class TableDesc
 
equals(Object) - Method in class TableDesc.RowFormatDesc
 
equals(Object) - Method in class TableDesc.SerdeDesc
 
equals(Object) - Method in class TableDesc.StorageFormatDesc
 
equals(Object) - Method in class TableDesc.StoredByDesc
 
ERROR - Static variable in class DataType
 
ErrorType - Enum in org.apache.hcatalog.common
Enum type representing the various errors throws by HCat.
exec(JobContext, Partition, Path) - Method in class HarOutputCommitterPostProcessor
 
EXEC_ENCODING_NAME - Static variable in class AppConfig
 
EXEC_ENVS_NAME - Static variable in class AppConfig
 
EXEC_MAX_BYTES_NAME - Static variable in class AppConfig
 
EXEC_MAX_PROCS_NAME - Static variable in class AppConfig
 
EXEC_TIMEOUT_NAME - Static variable in class AppConfig
 
ExecBean - Class in org.apache.hcatalog.templeton
ExecBean - The results of an exec call.
ExecBean() - Constructor for class ExecBean
 
ExecBean(String, String, int) - Constructor for class ExecBean
Create a new ExecBean.
execBean - Variable in class HcatException
 
execEnv(Map<String, String>) - Method in class ExecServiceImpl
Build the environment used for all exec calls.
ExecService - Interface in org.apache.hcatalog.templeton
 
execService - Static variable in class Server
 
ExecServiceImpl - Class in org.apache.hcatalog.templeton
Execute a local program.
execute() - Method in interface ZooKeeperOperation
Performs the operation - which may be involved multiple times if the connection to ZooKeeper closes during this operation
existingTable - Variable in class TableLikeDesc
 
exit() - Method in class HDFSCleanup
 
exit() - Method in class ZooKeeperCleanup
 
EXIT_FNAME - Static variable in class TempletonControllerJob
 
exitcode - Variable in class ExecBean
 
exitValue - Variable in class QueueStatusBean
 
external - Variable in class TableDesc
 
external - Variable in class TableLikeDesc
 
extractChildJobId(String) - Static method in class TempletonUtils
Extract the job id from jar jobs.
extractPercentComplete(String) - Static method in class TempletonUtils
Extract the percent complete line from Pig or Jar jobs.
extractSchema(Table) - Static method in class HCatUtil
 
extractSchema(Partition) - Static method in class HCatUtil
 
extractThriftToken(String, String) - Static method in class HCatUtil
 

F

FamilyRevision - Class in org.apache.hcatalog.hbase.snapshot
A FamiliyRevision class consists of a revision number and a expiration timestamp.
fetchUrl(URL) - Static method in class TempletonUtils
GET the given url.
fieldForId(int) - Method in class StoreFamilyRevision
 
fieldForId(int) - Method in class StoreFamilyRevisionList
 
fieldsTerminatedBy - Variable in class TableDesc.RowFormatDesc
 
fileFormat(String) - Method in class HCatCreateTableDesc.Builder
File format.
finalize() - Method in class NotificationListener
 
findByName(String) - Static method in enum StoreFamilyRevision._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum StoreFamilyRevisionList._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum StoreFamilyRevision._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum StoreFamilyRevisionList._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum StoreFamilyRevision._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum StoreFamilyRevisionList._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findType(Object) - Static method in class DataType
Determine the datatype of an object.
first - Variable in class Pair
 
FLOAT - Static variable in class DataType
 
format - Variable in class TableDesc
 
FosterStorageHandler - Class in org.apache.hcatalog.mapreduce
This class is used to encapsulate the InputFormat, OutputFormat and SerDe artifacts of tables which don't define a SerDe.
FosterStorageHandler(String, String, String) - Constructor for class FosterStorageHandler
 
FosterStorageHandler(Class<? extends InputFormat>, Class<? extends OutputFormat>, Class<? extends SerDe>) - Constructor for class FosterStorageHandler
 
fromType(HCatFieldSchema.Type) - Static method in enum HCatFieldSchema.Category
 

G

get(int) - Method in class DefaultHCatRecord
 
get(String, HCatSchema) - Method in class DefaultHCatRecord
 
get(String, HCatSchema) - Method in class HCatRecord
 
get(String, HCatSchema, Class) - Method in class HCatRecord
 
get(int) - Method in interface HCatRecordable
Gets the field at the specified index.
get(int) - Method in class LazyHCatRecord
 
get(String, HCatSchema) - Method in class LazyHCatRecord
 
get(String) - Method in class HCatSchema
 
get(int) - Method in class HCatSchema
 
get() - Static method in class DefaultStateProvider
 
get() - Static method in class HCatHadoopShims.Instance
 
getAbortedWriteTransactions(String, String) - Method in interface RevisionManager
Get the list of aborted Transactions for a column family
getAbortedWriteTransactions(String, String) - Method in class RevisionManagerEndpoint
 
getAbortedWriteTransactions(String, String) - Method in class RevisionManagerEndpointClient
 
getAbortedWriteTransactions(String, String) - Method in class ZKBasedRevisionManager
 
getAll() - Method in class DefaultHCatRecord
 
getAll() - Method in interface HCatRecordable
Gets all the fields of the hcat record.
getAll() - Method in class LazyHCatRecord
 
getAll() - Method in class HDFSStorage
 
getAll() - Method in interface TempletonStorage
Get the id of each data grouping in the storage system.
getAll() - Method in class ZooKeeperStorage
 
getAllForKey(String, String) - Method in class HDFSStorage
 
getAllForKey(String, String) - Method in interface TempletonStorage
Get the id of each data grouping that has the specific key/value pair.
getAllForKey(String, String) - Method in class ZooKeeperStorage
 
getAllForType(TempletonStorage.Type) - Method in class HDFSStorage
 
getAllForType(TempletonStorage.Type) - Method in interface TempletonStorage
Get the id of each data grouping of a given type in the storage system.
getAllForType(TempletonStorage.Type) - Method in class ZooKeeperStorage
 
getAllForTypeAndKey(TempletonStorage.Type, String, String) - Method in class HDFSStorage
 
getAllForTypeAndKey(TempletonStorage.Type, String, String) - Method in interface TempletonStorage
Get the id of each data grouping of a given type that has the specific key/value pair.
getAllForTypeAndKey(TempletonStorage.Type, String, String) - Method in class ZooKeeperStorage
 
getAllJobs() - Method in class TempletonJobTracker
Get all the jobs submitted.
getAppConfigInstance() - Static method in class Main
Retrieve the config singleton.
getArrayElementSchema() - Method in class HCatFieldSchema
 
getAuthorizationProvider() - Method in class HBaseHCatStorageHandler
 
getAuthorizationProvider() - Method in class FosterStorageHandler
 
getAuthorizationProvider() - Method in class HCatStorageHandler
 
getAuthProvider() - Method in class HCatSemanticAnalyzerBase
 
getBaseSplit() - Method in class HCatSplit
Gets the underlying InputSplit.
getBoolean(String, HCatSchema) - Method in class HCatRecord
 
getBucketCols() - Method in class HCatCreateTableDesc
Gets the bucket cols.
getBucketCols() - Method in class HCatPartition
Gets the bucket columns.
getBucketCols() - Method in class HCatTable
Gets the bucket columns.
getByte(String, HCatSchema) - Method in class HCatRecord
 
getByteArray(String, HCatSchema) - Method in class HCatRecord
 
getCallback() - Method in class JobState
The url callback
getCategory() - Method in class HCatFieldSchema
Returns category of the field
getChildId() - Method in class JobState
The child id of TempletonControllerJob
getChildList(ZooKeeper) - Method in class ZooKeeperCleanup
Get the list of jobs from JobState
getChildren() - Method in class JobState
Get a list of jobstates for jobs that are children of this job.
getCols() - Method in class HCatCreateTableDesc
Gets the cols.
getCols() - Method in class HCatTable
Gets the columns.
getColumnFamilies() - Method in class TableSnapshot
Gets the column families.
getColumnFamilies() - Method in class Transaction
 
getColumns() - Method in class HCatPartition
Gets the columns of the table.
getComment() - Method in class HCatDatabase
Gets the comment.
getComment() - Method in class HCatFieldSchema
 
getComments() - Method in class HCatCreateDBDesc
Gets the comments.
getComments() - Method in class HCatCreateTableDesc
Gets the comments.
getCompletedUrl() - Method in class Server
The callback url on this server when a task is completed.
getCompleteStatus() - Method in class JobState
The status of a job once it is completed.
getConf() - Method in enum HCatContext
Get the configuration, if there is one.
getConf() - Method in class HCatReader
 
getConf() - Method in class ReaderContext
 
getConf() - Method in class WriterContext
 
getConf() - Method in class HBaseHCatStorageHandler
 
getConf() - Method in class RevisionManagerEndpointClient
 
getConf() - Method in class FosterStorageHandler
 
getConf() - Method in class HCatStorageHandler
 
getCreated() - Method in class JobState
When this job was created.
getCreateTime() - Method in class HCatPartition
Gets the creates the time.
getCurrentKey() - Method in class RCFileMapReduceRecordReader
 
getCurrentKey() - Method in class NullRecordReader
 
getCurrentValue() - Method in class RCFileMapReduceRecordReader
 
getCurrentValue() - Method in class NullRecordReader
 
getDatabase(String) - Method in class HCatClient
Gets the database.
getDatabase(String) - Method in class HCatClientHMSImpl
 
getDatabaseName() - Method in class HCatAddPartitionDesc
Gets the database name.
getDatabaseName() - Method in class HCatCreateDBDesc
Gets the database name.
getDatabaseName() - Method in class HCatCreateTableDesc
Gets the database name.
getDatabaseName() - Method in class HCatPartition
Gets the database name.
getDatabaseName() - Method in class HCatTableSnapshot
 
getDatabaseName() - Method in class HCatTableInfo
Gets the value of databaseName
getDatabaseName() - Method in class InputJobInfo
Gets the value of databaseName
getDatabaseName() - Method in class OutputJobInfo
 
getDatabaseProperties() - Method in class HCatCreateDBDesc
Gets the database properties.
getDataColumns() - Method in class HCatTableInfo
 
getDataSchema() - Method in class HCatSplit
Gets the data schema.
getDbAndTableName(String) - Static method in class HCatUtil
 
getDbLocation(Database) - Method in class HdfsAuthorizationProvider
 
getDbName() - Method in class HCatTable
Gets the db name.
getDbName(Hive, String) - Method in class HCatSemanticAnalyzerBase
 
getDelegate(Table) - Method in class StorageDelegationAuthorizationProvider
Returns the StorageHandler of the Table obtained from the HCatStorageHandler
getDelegationToken(String, String) - Method in class HCatClient
Gets the delegation token.
getDelegationToken(String, String) - Method in class HCatClientHMSImpl
 
getDir() - Method in class WriteLock
return the parent dir for lock
getDouble(String, HCatSchema) - Method in class HCatRecord
 
getDynamicPartitioningKeys() - Method in class OutputJobInfo
 
getErrorCode() - Method in enum ErrorType
Gets the error code.
getErrorCode() - Method in exception HCatException
Gets the error code.
getErrorMessage() - Method in enum ErrorType
Gets the error message.
getErrorType() - Method in exception HCatException
Gets the error type.
getExitValue() - Method in class JobState
The system exit value of the job.
getExpireTimestamp() - Method in class FamilyRevision
 
getExternal() - Method in class HCatCreateTableDesc
Gets the external.
getField(TempletonStorage.Type, String, String) - Method in class HDFSStorage
 
getField(String) - Method in class JobState
 
getField(TempletonStorage.Type, String, String) - Method in interface TempletonStorage
Get the value of one field for a given data type.
getField(TempletonStorage.Type, String, String) - Method in class ZooKeeperStorage
 
getFieldName() - Method in enum StoreFamilyRevision._Fields
 
getFieldName() - Method in enum StoreFamilyRevisionList._Fields
 
getFieldNames() - Method in class HCatSchema
 
getFields() - Method in class HCatSchema
Users are not allowed to modify the list directly, since HCatSchema maintains internal state.
getFields(TempletonStorage.Type, String) - Method in class HDFSStorage
 
getFields(TempletonStorage.Type, String) - Method in interface TempletonStorage
Get all the name/value pairs stored for this id.
getFields(TempletonStorage.Type, String) - Method in class ZooKeeperStorage
 
getFieldSchema(HCatFieldSchema) - Static method in class HCatSchemaUtils
 
getFieldSchemaList(List<HCatFieldSchema>) - Static method in class HCatUtil
 
getFieldSchemas(List<HCatFieldSchema>) - Static method in class HCatSchemaUtils
 
getFieldValue(StoreFamilyRevision._Fields) - Method in class StoreFamilyRevision
 
getFieldValue(StoreFamilyRevisionList._Fields) - Method in class StoreFamilyRevisionList
 
getFileFormat() - Method in class HCatCreateTableDesc
Gets the file format.
getFilter() - Method in class InputJobInfo
Gets the value of partition filter
getFilterString() - Method in class ReadEntity
 
getFloat(String, HCatSchema) - Method in class HCatRecord
 
getFsAction(Privilege, Path) - Method in class HdfsAuthorizationProvider
 
getFsActions(Privilege[], Path) - Method in class HdfsAuthorizationProvider
 
getHadoopConfDir() - Method in class AppConfig
 
getHarRequested() - Method in class OutputJobInfo
Returns whether or not hadoop archiving has been requested for this job
getHCatFieldSchema(FieldSchema) - Static method in class HCatSchemaUtils
Convert a HCatFieldSchema to a FieldSchema
getHCatFieldSchemaList(FieldSchema...) - Static method in class HCatUtil
 
getHCatFieldSchemaList(List<FieldSchema>) - Static method in class HCatUtil
 
getHCatReader(ReadEntity, Map<String, String>) - Static method in class DataTransferFactory
This should be called once from master node to obtain an instance of HCatReader.
getHCatReader(InputSplit, Configuration) - Static method in class DataTransferFactory
This should only be called once from every slave node to obtain an instance of HCatReader.
getHCatReader(InputSplit, Configuration, StateProvider) - Static method in class DataTransferFactory
This should only be called once from every slave node to obtain an instance of HCatReader.
getHCatRecordObjectInspector(StructTypeInfo) - Static method in class HCatRecordObjectInspectorFactory
Returns HCatRecordObjectInspector given a StructTypeInfo type definition for the record to look into
getHCatSchema(Schema) - Static method in class HCatSchemaUtils
 
getHCatSchema(List<? extends FieldSchema>) - Static method in class HCatSchemaUtils
 
getHCatSchema(TypeInfo) - Static method in class HCatSchemaUtils
 
getHCatSchema(String) - Static method in class HCatSchemaUtils
 
getHCatSchemaFromTypeString(String) - Static method in class HCatSchemaUtils
 
getHcatServiceStr() - Method in class SecureProxySupport
The token to pass to hcat.
getHCatWriter(WriteEntity, Map<String, String>) - Static method in class DataTransferFactory
This should be called at master node to obtain an instance of HCatWriter.
getHCatWriter(WriterContext) - Static method in class DataTransferFactory
This should be called at slave nodes to obtain an instance of HCatWriter.
getHCatWriter(WriterContext, StateProvider) - Static method in class DataTransferFactory
This should be called at slave nodes to obtain an instance of HCatWriter.
getHiveClient(HiveConf) - Static method in class HCatUtil
Get or create a hive client depending on whether it exits in cache or not
getHiveConf(Configuration) - Static method in class HCatUtil
 
getHiveInternalColumnName(int) - Method in class JsonSerDe
 
getHiveRecordWriter(JobConf, Path, Class<? extends Writable>, boolean, Properties, Progressable) - Method in class HBaseBaseOutputFormat
 
getId() - Method in class DefaultStateProvider
Default implementation.
getId() - Method in interface StateProvider
This method should return id assigned to slave node.
getId() - Method in class WriteLock
return the id for this lock
getId() - Method in class JobState
This job id.
getIfClass() - Method in class StorerInfo
 
getIfNotExists() - Method in class HCatCreateDBDesc
Gets the if not exists.
getIfNotExists() - Method in class HCatCreateTableDesc
Gets the if not exists.
getInputFileFormat() - Method in class HCatTable
Gets the input file format.
getInputFormat() - Method in class HCatPartition
Gets the input format.
getInputFormat() - Method in class HCatLoader
 
getInputFormatClass() - Method in class HBaseHCatStorageHandler
 
getInputFormatClass() - Method in class FosterStorageHandler
 
getInputFormatClassName() - Method in class PartInfo
 
getInputJobProperties(HCatStorageHandler, InputJobInfo) - Static method in class HCatUtil
 
getInputStorageHandlerProperties() - Method in class PartInfo
Gets the input storage handler properties.
getInstance() - Static method in class ExecServiceImpl
Retrieve the singleton.
getInstance(Configuration) - Static method in class HDFSCleanup
 
getInstance() - Static method in class TrivialExecService
Retrieve the singleton.
getInstance(Configuration) - Static method in class ZooKeeperCleanup
 
getInteger(String, HCatSchema) - Method in class HCatRecord
 
getJob(String) - Method in class MultiOutputFormat.JobConfigurer
Get the Job configuration for a OutputFormat defined by the alias name.
getJobConf() - Method in class HBaseHCatStorageHandler
 
getJobConfFromContext(JobContext) - Static method in class HCatUtil
 
getJobContext(String, JobContext) - Static method in class MultiOutputFormat
Get the JobContext with the related OutputFormat configuration populated given the alias and the actual JobContext
getJobID() - Method in class JobStateTracker
Get the jobid for this tracking node
getJobInfo(JobContext) - Static method in class HCatBaseOutputFormat
Deprecated. use HCatBaseOutputFormat.getJobInfo(org.apache.hadoop.conf.Configuration)
getJobInfo(Configuration) - Static method in class HCatBaseOutputFormat
Gets the HCatOuputJobInfo object by reading the Configuration and deserializing the string.
getJobProfile(JobID) - Method in class TempletonJobTracker
Grab a handle to a job that is already known to the JobTracker.
getJobProperties() - Method in class PartInfo
Gets the job properties.
getJobs(Configuration) - Static method in class JobState
Get an id for each currently existing job, which can be used to create a JobState object.
getJobStatus(JobID) - Method in class TempletonJobTracker
Grab a handle to a job that is already known to the JobTracker.
getJobTrackerDelegationToken(Configuration, String) - Static method in class HCatUtil
 
getKeepAliveValue() - Method in class Transaction
Gets the keep alive value.
getLastAccessTime() - Method in class HCatPartition
Gets the last access time.
getLatestRevision() - Method in class TableSnapshot
 
getLength() - Method in class HCatSplit
 
getLength() - Method in class NullSplit
 
getList(String, HCatSchema) - Method in class HCatRecord
 
getListSchemaBuilder() - Static method in class HCatSchemaUtils
 
getLocation() - Method in class HCatAddPartitionDesc
Gets the location.
getLocation() - Method in class HCatCreateDBDesc
Gets the location.
getLocation() - Method in class HCatCreateTableDesc
Gets the location.
getLocation() - Method in class HCatDatabase
Gets the dB location.
getLocation() - Method in class HCatPartition
Gets the location.
getLocation() - Method in class HCatTable
Gets the location.
getLocation() - Method in class OutputJobInfo
 
getLocation() - Method in class PartInfo
Gets the value of location.
getLocations() - Method in class HCatSplit
 
getLocations() - Method in class NullSplit
 
getLockListener() - Method in class WriteLock
return the current locklistener
getLong(String, HCatSchema) - Method in class HCatRecord
 
getLongField(String) - Method in class JobState
Fetch an integer field from the store.
getMap(String, HCatSchema) - Method in class HCatRecord
 
getMap() - Method in class JsonBuilder
Get the underlying map.
getMapKeyType() - Method in class HCatFieldSchema
 
getMapRedInputFormat(JobConf, Class) - Static method in class HCatBaseInputFormat
 
getMapSchemaBuilder() - Static method in class HCatSchemaUtils
 
getMapValueSchema() - Method in class HCatFieldSchema
 
getMaxDynamicPartitions() - Method in class OutputJobInfo
Returns maximum number of allowable dynamic partitions
getMessageBusTopicName(String, String) - Method in class HCatClient
Retrieve Message-bus topic for a table.
getMessageBusTopicName(String, String) - Method in class HCatClientHMSImpl
 
getMetaHook() - Method in class HBaseHCatStorageHandler
 
getMetaHook() - Method in class FosterStorageHandler
 
getName() - Method in class HCatDatabase
Gets the database name.
getName() - Method in class HCatFieldSchema
Returns name of the field
getName() - Method in class ZNodeName
Returns the name of the znode
getNotifiedTime() - Method in class JobState
The time when the callback was sent.
getNumBuckets() - Method in class HCatCreateTableDesc
 
getNumBuckets() - Method in class HCatPartition
Gets the number of buckets.
getNumBuckets() - Method in class HCatTable
Gets the number of buckets.
getObjectInspector() - Method in class HCatRecordSerDe
Return an object inspector that can read through the object that we return from deserialize().
getObjectInspector() - Method in class JsonSerDe
Returns an object inspector for the specified schema that is capable of reading in the object representation of the JSON string
getOfClass() - Method in class StorerInfo
 
getOpenedRevisionManager(Configuration) - Static method in class RevisionManagerFactory
Gets an instance of revision manager which is opened.
getOutputCommitter(TaskAttemptContext) - Method in class HCatOutputFormat
Get the output committer for this output format.
getOutputCommitter(TaskAttemptContext) - Method in class MultiOutputFormat
 
getOutputFileFormat() - Method in class HCatTable
Gets the output file format.
getOutputFormat() - Method in class HCatPartition
Gets the output format.
getOutputFormat(JobContext) - Method in class HCatBaseOutputFormat
Gets the output format instance.
getOutputFormat() - Method in class HCatStorer
 
getOutputFormatClass() - Method in class HBaseHCatStorageHandler
 
getOutputFormatClass() - Method in class FosterStorageHandler
 
getOutputFormatClassName() - Method in class PartInfo
 
getOutputSchema() - Method in class OutputJobInfo
 
getParameters() - Method in class HCatPartition
 
getParentFSPath(Path) - Method in class HarOutputCommitterPostProcessor
 
getPartCols() - Method in class HCatTable
Gets the part columns.
getPartition(String, String, Map<String, String>) - Method in class HCatClient
Gets the partition.
getPartition(String, String, Map<String, String>) - Method in class HCatClientHMSImpl
 
getPartitionCols() - Method in class HCatCreateTableDesc
Gets the partition cols.
getPartitionColumns(Table) - Static method in class HCatUtil
return the partition columns from a table instance
getPartitionColumns() - Method in class HCatTableInfo
 
getPartitionInfo() - Method in class HCatSplit
Gets the partition info.
getPartitionKeys(String, Job) - Method in class HCatLoader
 
getPartitions(String, String) - Method in class HCatClient
Gets all the partitions.
getPartitions(String, String, Map<String, String>) - Method in class HCatClient
Gets all the partitions that match the specified (and possibly partial) partition specification.
getPartitions(String, String) - Method in class HCatClientHMSImpl
 
getPartitions(String, String, Map<String, String>) - Method in class HCatClientHMSImpl
 
getPartitions() - Method in class InputJobInfo
 
getPartitionSchema() - Method in class PartInfo
Gets the value of partitionSchema.
getPartitionSpec() - Method in class HCatAddPartitionDesc
Gets the partition spec.
getPartitionValues() - Method in class OutputJobInfo
Gets the value of partitionValues
getPartitionValues() - Method in class PartInfo
Gets the partition values.
getPath(TempletonStorage.Type) - Method in class HDFSStorage
Get the path to storage based on the type.
getPath(TempletonStorage.Type, String) - Static method in class HDFSStorage
Static method to get the path based on the type.
getPath(TempletonStorage.Type) - Method in class ZooKeeperStorage
Get the path based on the job type.
getPaths(String) - Static method in class ZooKeeperStorage
 
getPercentComplete() - Method in class JobState
The percent complete of a job
getPosition(String) - Method in class HCatSchema
 
getPositionFromHiveInternalColumnName(String) - Method in class JsonSerDe
 
getPosOfDynPartCols() - Method in class OutputJobInfo
 
getPosOfPartCols() - Method in class OutputJobInfo
 
getPrefix() - Method in class ZNodeName
Returns the text prefix before the sequence number
getProcessedLocation(Path) - Method in class HarOutputCommitterPostProcessor
 
getProgress() - Method in class RCFileMapReduceRecordReader
 
getProgress() - Method in class NullRecordReader
 
getProperties() - Method in class HCatDatabase
Gets the dB properties.
getProperties() - Method in class InputJobInfo
Set/Get Property information to be passed down to *StorageHandler implementation put implementation specific storage handler configurations here
getProperties() - Method in class OutputJobInfo
Set/Get Property information to be passed down to *StorageHandler implementation put implementation specific storage handler configurations here
getProperties() - Method in class StorerInfo
 
getPropertyName(HCatHadoopShims.PropertyName) - Method in interface HCatHadoopShims
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class HBaseBaseOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class HCatOutputFormat
Get the record writer for the job.
getRecordWriter(TaskAttemptContext) - Method in class MultiOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class RCFileMapReduceOutputFormat
 
getResourceManagerAddress(Configuration) - Method in interface HCatHadoopShims
 
getResponse() - Method in class SimpleWebException
 
getRevision() - Method in class FamilyRevision
 
getRevision(String) - Method in class TableSnapshot
Gets the revision.
getRevision() - Method in class StoreFamilyRevision
 
getRevisionList() - Method in class StoreFamilyRevisionList
 
getRevisionListIterator() - Method in class StoreFamilyRevisionList
 
getRevisionListSize() - Method in class StoreFamilyRevisionList
 
getRevisionNumber() - Method in class Transaction
 
getSchema(String, Job) - Method in class HCatLoader
 
getSchemaAsTypeString() - Method in class HCatSchema
 
getSerDe() - Method in class HCatPartition
Gets the serde.
getSerDeClass() - Method in class HBaseHCatStorageHandler
 
getSerDeClass() - Method in class FosterStorageHandler
 
getSerdeClass() - Method in class StorerInfo
 
getSerdeClassName() - Method in class PartInfo
 
getSerdeLib() - Method in class HCatTable
Gets the serde lib.
getSerDeStats() - Method in class HCatRecordSerDe
 
getSerDeStats() - Method in class JsonSerDe
 
getSerializedClass() - Method in class HCatRecordSerDe
 
getSerializedClass() - Method in class JsonSerDe
 
getShort(String, HCatSchema) - Method in class HCatRecord
 
getSortCols() - Method in class HCatCreateTableDesc
Gets the sort cols.
getSortCols() - Method in class HCatPartition
Gets the sort columns.
getSortCols() - Method in class HCatTable
Gets the sort columns.
getSplits() - Method in class ReaderContext
 
getSplits(JobContext) - Method in class HCatBaseInputFormat
Logically split the set of input files for the job.
getSplits(JobContext) - Method in class RCFileMapReduceInputFormat
 
getSplits(JobContext) - Method in class SingleInputFormat
 
getStandardObjectInspectorFromTypeInfo(TypeInfo) - Static method in class HCatRecordObjectInspectorFactory
 
getStatistics(String, Job) - Method in class HCatLoader
Get statistics about the data to be loaded.
getStorage(Configuration) - Static method in class JobState
Get an open instance of the selected storage class.
getStorageHandler() - Method in class HCatCreateTableDesc
Gets the storage handler.
getStorageHandler() - Method in class HCatPartition
Gets the storage handler.
getStorageHandler() - Method in class HCatTable
Gets the storage handler.
getStorageHandler(Configuration, StorerInfo) - Static method in class HCatUtil
Create an instance of a storage handler defined in storerInfo.
getStorageHandler(Configuration, PartInfo) - Static method in class HCatUtil
 
getStorageHandler(Configuration, String, String, String, String) - Static method in class HCatUtil
Create an instance of a storage handler.
getStorageHandlerClass() - Method in class StorerInfo
 
getStorageHandlerClassName() - Method in class PartInfo
 
getStorageInstance(Configuration) - Static method in class JobState
Get an instance of the selected storage class.
getStorerInfo() - Method in class HCatTableInfo
 
getString(String, HCatSchema) - Method in class HCatRecord
 
getStruct(String, HCatSchema) - Method in class HCatRecord
 
getStructFieldData(Object, StructField) - Method in class HCatRecordObjectInspector
 
getStructFieldsDataAsList(Object) - Method in class HCatRecordObjectInspector
 
getStructSchemaBuilder() - Static method in class HCatSchemaUtils
 
getStructSubSchema() - Method in class HCatFieldSchema
 
getSubmittedId() - Method in class TempletonControllerJob
 
getTable(String, String) - Method in class HCatClient
Gets the table.
getTable(String, String) - Method in class HCatClientHMSImpl
 
getTable(HiveMetaStoreClient, String, String) - Static method in class HCatUtil
 
getTableInfo() - Method in class InputJobInfo
Gets the table's meta information
getTableInfo() - Method in class OutputJobInfo
 
getTableInfo() - Method in class PartInfo
Gets the HCatalog table information.
getTableLocation() - Method in class HCatTableInfo
 
getTableName() - Method in class HCatAddPartitionDesc
Gets the table name.
getTableName() - Method in class HCatCreateTableDesc
Gets the table name.
getTableName() - Method in class HCatPartition
Gets the table name.
getTableName() - Method in class HCatTable
Gets the table name.
getTableName() - Method in class HCatTableSnapshot
 
getTableName() - Method in class TableSnapshot
Gets the table name.
getTableName() - Method in class Transaction
 
getTableName() - Method in class HCatTableInfo
Gets the value of tableName
getTableName() - Method in class InputJobInfo
Gets the value of tableName
getTableName() - Method in class OutputJobInfo
 
getTableSchema(JobContext) - Static method in class HCatBaseInputFormat
Deprecated. Use HCatBaseInputFormat.getTableSchema(org.apache.hadoop.conf.Configuration)
getTableSchema(Configuration) - Static method in class HCatBaseInputFormat
Gets the HCatTable schema for the table specified in the HCatInputFormat.setInput call on the specified job context.
getTableSchema(JobContext) - Static method in class HCatBaseOutputFormat
Deprecated. Use HCatBaseOutputFormat.getTableSchema(org.apache.hadoop.conf.Configuration)
getTableSchema(Configuration) - Static method in class HCatBaseOutputFormat
Gets the table schema for the table specified in the HCatOutputFormat.setOutput call on the specified job context.
getTableSchema() - Method in class HCatSplit
Gets the table schema.
getTableSchemaWithPtnCols(Table) - Static method in class HCatUtil
 
getTabletype() - Method in class HCatTable
Gets the tabletype.
getTaskAttemptContext(String, TaskAttemptContext) - Static method in class MultiOutputFormat
Get the TaskAttemptContext with the related OutputFormat configuration populated given the alias and the actual TaskAttemptContext
getTblProps() - Method in class HCatCreateTableDesc
Gets the tbl props.
getTblProps() - Method in class HCatTable
Gets the table props.
getTempletonDir() - Static method in class AppConfig
 
getThriftFieldId() - Method in enum StoreFamilyRevision._Fields
 
getThriftFieldId() - Method in enum StoreFamilyRevisionList._Fields
 
getTimestamp() - Method in class StoreFamilyRevision
 
getTokenPath() - Method in class SecureProxySupport
The file where we store the auth token
getTopic(String) - Method in class NotificationListener
Get the topic object for the topicName, it also tries to reconnect if the connection appears to be broken.
getTrackingJobs(Configuration, ZooKeeper) - Static method in class JobStateTracker
 
getType() - Method in class HCatFieldSchema
Returns type of the field
getTypeString() - Method in class HCatFieldSchema
 
getUser() - Method in class Server
Get the user name from the security context.
getUser() - Method in class JobState
The user who started this job.
getValues() - Method in class HCatPartition
Gets the values.
getWritable() - Method in class LazyHCatRecord
Convert this LazyHCatRecord to a DefaultHCatRecord.
getZNodeName() - Method in class ZNodeName
Returns the sequence number
group - Variable in class GroupPermissionsDesc
 
GroupPermissionsDesc - Class in org.apache.hcatalog.templeton
The base create permissions for ddl objects.
GroupPermissionsDesc() - Constructor for class GroupPermissionsDesc
 

H

HADOOP_CHILD_JAVA_OPTS - Static variable in class AppConfig
 
HADOOP_CONF_DIR - Static variable in class AppConfig
 
HADOOP_CONF_FILENAMES - Static variable in class AppConfig
 
HADOOP_END_INTERVAL_NAME - Static variable in class AppConfig
 
HADOOP_END_RETRY_NAME - Static variable in class AppConfig
 
HADOOP_END_URL_NAME - Static variable in class AppConfig
 
HADOOP_NAME - Static variable in class AppConfig
 
HADOOP_PREFIX_VARS - Static variable in class AppConfig
 
HADOOP_SPECULATIVE_NAME - Static variable in class AppConfig
 
hadoopFsFilename(String, Configuration, String) - Static method in class TempletonUtils
 
hadoopFsIsMissing(FileSystem, Path) - Static method in class TempletonUtils
 
hadoopFsListAsArray(String, Configuration, String) - Static method in class TempletonUtils
 
hadoopFsListAsString(String, Configuration, String) - Static method in class TempletonUtils
 
hadoopFsPath(String, Configuration, String) - Static method in class TempletonUtils
 
hadoopUserEnv(String, String) - Static method in class TempletonUtils
Set the environment variables to specify the hadoop user.
harFile(Path) - Method in class HarOutputCommitterPostProcessor
 
HarOutputCommitterPostProcessor - Class in org.apache.hcatalog.har
 
HarOutputCommitterPostProcessor() - Constructor for class HarOutputCommitterPostProcessor
 
hashCode() - Method in class DefaultHCatRecord
 
hashCode() - Method in class Pair
 
hashCode() - Method in class HCatSchema
 
hashCode() - Method in class ZNodeName
 
hashCode() - Method in class StoreFamilyRevision
 
hashCode() - Method in class StoreFamilyRevisionList
 
hashCode() - Method in class HCatTableInfo
 
HBaseBaseOutputFormat - Class in org.apache.hcatalog.hbase
 
HBaseBaseOutputFormat() - Constructor for class HBaseBaseOutputFormat
 
HBaseHCatStorageHandler - Class in org.apache.hcatalog.hbase
This class HBaseHCatStorageHandler provides functionality to create HBase tables through HCatalog.
HBaseHCatStorageHandler() - Constructor for class HBaseHCatStorageHandler
 
HCAT_ADD_DATABASE_EVENT - Static variable in class HCatConstants
 
HCAT_ADD_PARTITION_EVENT - Static variable in class HCatConstants
 
HCAT_ADD_TABLE_EVENT - Static variable in class HCatConstants
 
HCAT_CLIENT_IMPL_CLASS - Static variable in class HCatClient
 
HCAT_CREATE_DB_NAME - Static variable in class HCatConstants
 
HCAT_CREATE_TBL_NAME - Static variable in class HCatConstants
 
HCAT_DATA_CONVERT_BOOLEAN_TO_INTEGER - Static variable in class HCatConstants
"hcat.data.convert.boolean.to.integer" (default: false).
HCAT_DATA_CONVERT_BOOLEAN_TO_INTEGER_DEFAULT - Static variable in class HCatConstants
 
HCAT_DATA_TINY_SMALL_INT_PROMOTION - Static variable in class HCatConstants
"hcat.data.tiny.small.int.promotion" (default: false).
HCAT_DATA_TINY_SMALL_INT_PROMOTION_DEFAULT - Static variable in class HCatConstants
 
HCAT_DEFAULT_TOPIC_PREFIX - Static variable in class HCatConstants
 
HCAT_DESIRED_PARTITION_NUM_SPLITS - Static variable in class HCatConstants
The desired number of input splits produced for each partition.
HCAT_DROP_DATABASE_EVENT - Static variable in class HCatConstants
 
HCAT_DROP_PARTITION_EVENT - Static variable in class HCatConstants
 
HCAT_DROP_TABLE_EVENT - Static variable in class HCatConstants
 
HCAT_DYNAMIC_PTN_JOBID - Static variable in class HCatConstants
 
HCAT_EVENT - Static variable in class HCatConstants
 
HCAT_GROUP - Static variable in class HCatConstants
 
HCAT_HIVE_CLIENT_EXPIRY_TIME - Static variable in class HCatConstants
 
HCAT_INPUT_BAD_RECORD_MIN_DEFAULT - Static variable in class HCatConstants
 
HCAT_INPUT_BAD_RECORD_MIN_KEY - Static variable in class HCatConstants
"hcat.input.bad.record.min" (default: 2).
HCAT_INPUT_BAD_RECORD_THRESHOLD_DEFAULT - Static variable in class HCatConstants
 
HCAT_INPUT_BAD_RECORD_THRESHOLD_KEY - Static variable in class HCatConstants
"hcat.input.bad.record.threshold" (default: 9.999999747378752E-5f).
HCAT_IS_DYNAMIC_MAX_PTN_CHECK_ENABLED - Static variable in class HCatConstants
 
HCAT_KEY_BASE - Static variable in class HCatConstants
 
HCAT_KEY_HIVE_CONF - Static variable in class HCatConstants
 
HCAT_KEY_JOB_INFO - Static variable in class HCatConstants
 
HCAT_KEY_OUTPUT_BASE - Static variable in class HCatConstants
 
HCAT_KEY_OUTPUT_INFO - Static variable in class HCatConstants
 
HCAT_KEY_OUTPUT_SCHEMA - Static variable in class HCatConstants
 
HCAT_KEY_TOKEN_SIGNATURE - Static variable in class HCatConstants
 
HCAT_METASTORE_PRINCIPAL - Static variable in class HCatConstants
 
HCAT_METASTORE_URI - Static variable in class HCatConstants
 
HCAT_MSG_CLEAN_FREQ - Static variable in class HCatConstants
 
HCAT_MSG_EXPIRY_DURATION - Static variable in class HCatConstants
 
HCAT_MSGBUS_TOPIC_NAME - Static variable in class HCatConstants
 
HCAT_MSGBUS_TOPIC_NAMING_POLICY - Static variable in class HCatConstants
 
HCAT_MSGBUS_TOPIC_PREFIX - Static variable in class HCatConstants
 
HCAT_NAME - Static variable in class AppConfig
 
HCAT_PARTITION_DONE_EVENT - Static variable in class HCatConstants
 
HCAT_PERMS - Static variable in class HCatConstants
 
HCAT_PIG_ARGS_DELIMIT - Static variable in class HCatConstants
 
HCAT_PIG_ARGS_DELIMIT_DEFAULT - Static variable in class HCatConstants
 
HCAT_PIG_INNER_FIELD_NAME - Static variable in class HCatConstants
 
HCAT_PIG_INNER_FIELD_NAME_DEFAULT - Static variable in class HCatConstants
 
HCAT_PIG_INNER_TUPLE_NAME - Static variable in class HCatConstants
 
HCAT_PIG_INNER_TUPLE_NAME_DEFAULT - Static variable in class HCatConstants
 
HCAT_PIG_LOADER - Static variable in class HCatConstants
 
HCAT_PIG_LOADER_ARGS - Static variable in class HCatConstants
 
HCAT_PIG_LOADER_LOCATION_SET - Static variable in class HCatConstants
 
HCAT_PIG_STORAGE_CLASS - Static variable in class HCatConstants
 
HCAT_PIG_STORER - Static variable in class HCatConstants
 
HCAT_PIG_STORER_ARGS - Static variable in class HCatConstants
 
HCAT_PIG_STORER_EXTERNAL_LOCATION - Static variable in class HCatConstants
"hcat.pig.storer.external.location" (default: null) When the property is set in the UDFContext of the org.apache.hcatalog.pig.HCatStorer, HCatStorer writes to the location it specifies instead of the default HCatalog location format.
HCAT_PIG_STORER_LOCATION_SET - Static variable in class HCatConstants
 
HCAT_TABLE_SCHEMA - Static variable in class HCatConstants
 
HCatAddPartitionDesc - Class in org.apache.hcatalog.api
The Class HCatAddPartitionDesc helps users in defining partition attributes.
HCatAddPartitionDesc.Builder - Class in org.apache.hcatalog.api
 
HCatBaseInputFormat - Class in org.apache.hcatalog.mapreduce
 
HCatBaseInputFormat() - Constructor for class HCatBaseInputFormat
 
HCatBaseOutputFormat - Class in org.apache.hcatalog.mapreduce
 
HCatBaseOutputFormat() - Constructor for class HCatBaseOutputFormat
 
HCatCli - Class in org.apache.hcatalog.cli
 
HCatCli() - Constructor for class HCatCli
 
HCatClient - Class in org.apache.hcatalog.api
The abstract class HCatClient containing APIs for HCatalog DDL commands.
HCatClient() - Constructor for class HCatClient
 
HCatClient.DropDBMode - Enum in org.apache.hcatalog.api
 
HCatClientHMSImpl - Class in org.apache.hcatalog.api
The HCatClientHMSImpl is the Hive Metastore client based implementation of HCatClient.
HCatClientHMSImpl() - Constructor for class HCatClientHMSImpl
 
HCatConstants - Class in org.apache.hcatalog.common
 
HCatContext - Enum in org.apache.hcatalog.common
HCatContext is a singleton that provides global access to configuration data.
HCatCreateDBDesc - Class in org.apache.hcatalog.api
The Class HCatCreateDBDesc for defining database attributes.
HCatCreateDBDesc.Builder - Class in org.apache.hcatalog.api
 
HCatCreateTableDesc - Class in org.apache.hcatalog.api
The Class HCatCreateTableDesc for defining attributes for a new table.
HCatCreateTableDesc.Builder - Class in org.apache.hcatalog.api
 
HCatDatabase - Class in org.apache.hcatalog.api
HCatDatabase is wrapper class around org.apache.hadoop.hive.metastore.api.Database.
HcatDelegator - Class in org.apache.hcatalog.templeton
Run hcat on the local server using the ExecService.
HcatDelegator(AppConfig, ExecService) - Constructor for class HcatDelegator
 
HCatDriver - Class in org.apache.hcatalog.cli
 
HCatDriver() - Constructor for class HCatDriver
 
HCatException - Exception in org.apache.hcatalog.common
Class representing exceptions thrown by HCat.
HCatException(ErrorType) - Constructor for exception HCatException
Instantiates a new hcat exception.
HCatException(ErrorType, Throwable) - Constructor for exception HCatException
Instantiates a new hcat exception.
HCatException(ErrorType, String) - Constructor for exception HCatException
Instantiates a new hcat exception.
HCatException(ErrorType, String, Throwable) - Constructor for exception HCatException
Instantiates a new hcat exception.
HCatException(String) - Constructor for exception HCatException
Instantiates a new hcat exception.
HCatException(String, Throwable) - Constructor for exception HCatException
Instantiates a new hcat exception.
HcatException - Class in org.apache.hcatalog.templeton
Unable to run hcat on the job.
HcatException(String, ExecBean, String) - Constructor for class HcatException
 
HCatFieldSchema - Class in org.apache.hcatalog.data.schema
 
HCatFieldSchema(String, HCatFieldSchema.Type, String) - Constructor for class HCatFieldSchema
Constructor constructing a primitive datatype HCatFieldSchema
HCatFieldSchema(String, HCatFieldSchema.Type, HCatSchema, String) - Constructor for class HCatFieldSchema
Constructor for constructing a ARRAY type or STRUCT type HCatFieldSchema, passing type and subschema
HCatFieldSchema(String, HCatFieldSchema.Type, HCatFieldSchema.Type, HCatSchema, String) - Constructor for class HCatFieldSchema
Constructor for constructing a MAP type HCatFieldSchema, passing type of key and value
HCatFieldSchema.Category - Enum in org.apache.hcatalog.data.schema
 
HCatFieldSchema.Type - Enum in org.apache.hcatalog.data.schema
 
HCatHadoopShims - Interface in org.apache.hcatalog.shims
Shim layer to abstract differences between Hadoop 0.20 and 0.23 (HCATALOG-179).
HCatHadoopShims.Instance - Class in org.apache.hcatalog.shims
 
HCatHadoopShims.Instance() - Constructor for class HCatHadoopShims.Instance
 
HCatHadoopShims.PropertyName - Enum in org.apache.hcatalog.shims
 
HCatInputFormat - Class in org.apache.hcatalog.mapreduce
The InputFormat to use to read data from HCatalog.
HCatInputFormat() - Constructor for class HCatInputFormat
 
HCatInputFormatReader - Class in org.apache.hcatalog.data.transfer.impl
This reader reads via HCatInputFormat
HCatInputFormatReader(InputSplit, Configuration, StateProvider) - Constructor for class HCatInputFormatReader
 
HCatInputFormatReader(ReadEntity, Map<String, String>) - Constructor for class HCatInputFormatReader
 
HCatLoader - Class in org.apache.hcatalog.pig
Pig LoadFunc to read data from HCat
HCatLoader() - Constructor for class HCatLoader
 
HCatMapRedUtil - Class in org.apache.hadoop.mapred
 
HCatMapRedUtil() - Constructor for class HCatMapRedUtil
 
HCatOutputFormat - Class in org.apache.hcatalog.mapreduce
The OutputFormat to use to write data to HCatalog.
HCatOutputFormat() - Constructor for class HCatOutputFormat
 
HCatOutputFormatWriter - Class in org.apache.hcatalog.data.transfer.impl
This writer writes via HCatOutputFormat
HCatOutputFormatWriter(WriteEntity, Map<String, String>) - Constructor for class HCatOutputFormatWriter
 
HCatOutputFormatWriter(Configuration, StateProvider) - Constructor for class HCatOutputFormatWriter
 
HCatPartition - Class in org.apache.hcatalog.api
The HCatPartition is a wrapper around org.apache.hadoop.hive.metastore.api.Partition.
HCatReader - Class in org.apache.hcatalog.data.transfer
This abstract class is internal to HCatalog and abstracts away the notion of underlying system from which reads will be done.
HCatReader(ReadEntity, Map<String, String>) - Constructor for class HCatReader
This constructor will be invoked by DataTransferFactory at master node.
HCatReader(Configuration, StateProvider) - Constructor for class HCatReader
This constructor will be invoked by DataTransferFactory at slave nodes.
HCatRecord - Class in org.apache.hcatalog.data
Abstract class exposing get and set semantics for basic record usage.
HCatRecord() - Constructor for class HCatRecord
 
HCatRecordable - Interface in org.apache.hcatalog.data
Interface that determines whether we can implement a HCatRecord on top of it
HCatRecordObjectInspector - Class in org.apache.hcatalog.data
 
HCatRecordObjectInspector(List<String>, List<ObjectInspector>) - Constructor for class HCatRecordObjectInspector
 
HCatRecordObjectInspectorFactory - Class in org.apache.hcatalog.data
ObjectInspectorFactory for HCatRecordObjectInspectors (and associated helper inspectors)
HCatRecordObjectInspectorFactory() - Constructor for class HCatRecordObjectInspectorFactory
 
HCatRecordSerDe - Class in org.apache.hcatalog.data
SerDe class for serializing to and from HCatRecord
HCatRecordSerDe() - Constructor for class HCatRecordSerDe
 
HCatSchema - Class in org.apache.hcatalog.data.schema
HCatSchema.
HCatSchema(List<HCatFieldSchema>) - Constructor for class HCatSchema
 
HCatSchemaUtils - Class in org.apache.hcatalog.data.schema
 
HCatSchemaUtils() - Constructor for class HCatSchemaUtils
 
HCatSchemaUtils.CollectionBuilder - Class in org.apache.hcatalog.data.schema
 
HCatSchemaUtils.HCatSchemaBuilder - Class in org.apache.hcatalog.data.schema
 
HCatSchemaUtils.HCatSchemaBuilder() - Constructor for class HCatSchemaUtils.HCatSchemaBuilder
 
HCatSchemaUtils.MapBuilder - Class in org.apache.hcatalog.data.schema
 
HCatSchemaUtils.MapBuilder() - Constructor for class HCatSchemaUtils.MapBuilder
 
HCatSemanticAnalyzer - Class in org.apache.hcatalog.cli.SemanticAnalysis
 
HCatSemanticAnalyzer() - Constructor for class HCatSemanticAnalyzer
 
HCatSemanticAnalyzerBase - Class in org.apache.hcatalog.cli.SemanticAnalysis
Base class for HCatSemanticAnalyzer hooks.
HCatSemanticAnalyzerBase() - Constructor for class HCatSemanticAnalyzerBase
 
HCatSplit - Class in org.apache.hcatalog.mapreduce
The HCatSplit wrapper around the InputSplit returned by the underlying InputFormat
HCatSplit() - Constructor for class HCatSplit
Instantiates a new hcat split.
HCatSplit(PartInfo, InputSplit, HCatSchema) - Constructor for class HCatSplit
Instantiates a new hcat split.
HCatStorageHandler - Class in org.apache.hcatalog.mapreduce
The abstract Class HCatStorageHandler would server as the base class for all the storage handlers required for non-native tables in HCatalog.
HCatStorageHandler() - Constructor for class HCatStorageHandler
 
HCatStorer - Class in org.apache.hcatalog.pig
HCatStorer.
HCatStorer(String, String) - Constructor for class HCatStorer
 
HCatStorer(String) - Constructor for class HCatStorer
 
HCatStorer() - Constructor for class HCatStorer
 
HCatTable - Class in org.apache.hcatalog.api
The HCatTable is a wrapper around org.apache.hadoop.hive.metastore.api.Table.
HCatTableInfo - Class in org.apache.hcatalog.mapreduce
HCatTableInfo - class to communicate table information to HCatInputFormat and HCatOutputFormat
HCatTableSnapshot - Class in org.apache.hcatalog.hbase
The class HCatTableSnapshot represents a snapshot of a hcatalog table.
HCatUtil - Class in org.apache.hcatalog.common
 
HCatUtil() - Constructor for class HCatUtil
 
HCatWriter - Class in org.apache.hcatalog.data.transfer
This abstraction is internal to HCatalog.
HCatWriter(WriteEntity, Map<String, String>) - Constructor for class HCatWriter
This constructor will be used at master node
HCatWriter(Configuration, StateProvider) - Constructor for class HCatWriter
This constructor will be used at slave nodes.
HDFS_CLEANUP_INTERVAL - Static variable in class HDFSCleanup
 
HDFS_CLEANUP_MAX_AGE - Static variable in class HDFSCleanup
 
HdfsAuthorizationProvider - Class in org.apache.hcatalog.security
An AuthorizationProvider, which checks against the data access level permissions on HDFS.
HdfsAuthorizationProvider() - Constructor for class HdfsAuthorizationProvider
 
HdfsAuthorizationProvider(Configuration) - Constructor for class HdfsAuthorizationProvider
 
hdfsAuthorizer - Variable in class StorageDelegationAuthorizationProvider
 
HDFSCleanup - Class in org.apache.hcatalog.templeton.tool
This does periodic cleanup
HDFSStorage - Class in org.apache.hcatalog.templeton.tool
HDFS implementation of templeton storage.
HDFSStorage() - Constructor for class HDFSStorage
 
hive(String, String, List<String>, String, String) - Method in class Server
Run a Hive job.
HIVE_ARCHIVE_NAME - Static variable in class AppConfig
 
HIVE_PATH_NAME - Static variable in class AppConfig
 
HIVE_PROPS_NAME - Static variable in class AppConfig
 
HIVE_RCFILE_IF_CLASS - Static variable in class HCatConstants
 
HIVE_RCFILE_OF_CLASS - Static variable in class HCatConstants
 
hiveArchive() - Method in class AppConfig
 
HiveDelegator - Class in org.apache.hcatalog.templeton
Submit a Hive job.
HiveDelegator(AppConfig) - Constructor for class HiveDelegator
 
hivePath() - Method in class AppConfig
 
httpCode - Variable in class SimpleWebException
 

I

id - Variable in class EnqueueBean
 
id - Variable in class QueueStatusBean
 
ID_PATTERNS - Static variable in class TempletonUtils
 
ifNotExists(boolean) - Method in class HCatCreateDBDesc.Builder
If not exists.
ifNotExists(boolean) - Method in class HCatCreateTableDesc.Builder
If not exists.
ifNotExists - Variable in class DatabaseDesc
 
ifNotExists - Variable in class PartitionDesc
 
ifNotExists - Variable in class TableDesc
 
ifNotExists - Variable in class TableLikeDesc
 
info - Variable in class HCatReader
 
info - Variable in class HCatWriter
 
init(Configuration) - Method in class HdfsAuthorizationProvider
 
init(Configuration) - Method in class StorageDelegationAuthorizationProvider
 
init(String[]) - Method in class Main
 
initialize(Configuration, Properties) - Method in class HCatRecordSerDe
 
initialize(HCatSchema) - Method in class HCatRecordSerDe
 
initialize(Configuration, Properties) - Method in class JsonSerDe
 
initialize(Configuration) - Method in interface RevisionManager
Initialize the revision manager.
initialize(Configuration) - Method in class RevisionManagerEndpoint
 
initialize(Configuration) - Method in class RevisionManagerEndpointClient
 
initialize(Configuration) - Method in class ZKBasedRevisionManager
 
initialize(InputSplit, TaskAttemptContext) - Method in class RCFileMapReduceRecordReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class NullRecordReader
 
INNER_SIGNATURE - Static variable in class HCatLoader
 
INNER_SIGNATURE - Static variable in class HCatStorer
 
INNER_SIGNATURE_PREFIX - Static variable in class HCatLoader
 
INNER_SIGNATURE_PREFIX - Static variable in class HCatStorer
 
InputJobInfo - Class in org.apache.hcatalog.mapreduce
Container for metadata read from the metadata server.
INTEGER - Static variable in class DataType
 
interval - Static variable in class HDFSCleanup
 
interval - Static variable in class ZooKeeperCleanup
 
isBulkMode(OutputJobInfo) - Static method in class HBaseHCatStorageHandler
 
isComplex() - Method in class HCatFieldSchema
 
isDynamicPartitioningUsed() - Method in class OutputJobInfo
Returns whether or not Dynamic Partitioning is used
isEnabled() - Method in class HarOutputCommitterPostProcessor
 
isError(Map) - Static method in class JsonBuilder
Check if this is an error doc.
isFileInHDFS(FileSystem, Path) - Method in interface HCatHadoopShims
Checks if file is in HDFS filesystem.
isOwner() - Method in class WriteLock
Returns true if this node is the owner of the lock (or the leader)
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class HCatClient
Checks if a partition is marked for event.
isPartitionMarkedForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class HCatClientHMSImpl
 
isRetriable() - Method in enum ErrorType
Checks if this is a retriable error.
isRetriable() - Method in exception HCatException
Is this a retriable error.
isSet(StoreFamilyRevision._Fields) - Method in class StoreFamilyRevision
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StoreFamilyRevisionList._Fields) - Method in class StoreFamilyRevisionList
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isset() - Method in class JsonBuilder
Is the object non-empty?
isset(String) - Static method in class TempletonUtils
Is the object non-empty?
isset(char) - Static method in class TempletonUtils
Is the object non-empty?
isset(T[]) - Static method in class TempletonUtils
Is the object non-empty?
isset(Collection<T>) - Static method in class TempletonUtils
Is the object non-empty?
isset(Map<K, V>) - Static method in class TempletonUtils
Is the object non-empty?
isSetRevision() - Method in class StoreFamilyRevision
Returns true if field revision is set (has been assigned a value) and false otherwise
isSetRevisionList() - Method in class StoreFamilyRevisionList
Returns true if field revisionList is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class StoreFamilyRevision
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isTableExternal(boolean) - Method in class HCatCreateTableDesc.Builder
Checks if is table external.

J

JAR_ARGS_NAME - Static variable in class TempletonControllerJob
 
JAR_CLASS - Static variable in class LauncherDelegator
 
JAR_COMPLETE - Static variable in class TempletonUtils
 
JAR_ID - Static variable in class TempletonUtils
 
JarDelegator - Class in org.apache.hcatalog.templeton
Submit a job to the MapReduce queue.
JarDelegator(AppConfig) - Constructor for class JarDelegator
 
JavaAction - Class in org.apache.hcatalog.oozie
 
JavaAction() - Constructor for class JavaAction
 
JOB_PATH - Static variable in class HDFSStorage
 
job_path - Variable in class ZooKeeperStorage
 
JOB_TRACKINGPATH - Static variable in class HDFSStorage
 
job_trackingpath - Variable in class ZooKeeperStorage
 
JobState - Class in org.apache.hcatalog.templeton.tool
The persistent state of a job.
JobState(String, Configuration) - Constructor for class JobState
 
JobStateTracker - Class in org.apache.hcatalog.templeton.tool
 
JobStateTracker(String, ZooKeeper, boolean, String) - Constructor for class JobStateTracker
Constructor for a new node -- takes the jobid of an existing job
JsonBuilder - Class in org.apache.hcatalog.templeton
Helper class to build new json objects with new top level properties.
JsonSerDe - Class in org.apache.hcatalog.data
 
JsonSerDe() - Constructor for class JsonSerDe
 
jsonToMap(String) - Static method in class JsonBuilder
Convert a json string to a Map.

K

KEEP_ALIVE_MSEC - Static variable in class TempletonControllerJob
 
keepAlive(Transaction) - Method in interface RevisionManager
Extends the expiration of a transaction by the time indicated by keep alive.
keepAlive(Transaction) - Method in class RevisionManagerEndpoint
 
keepAlive(Transaction) - Method in class RevisionManagerEndpointClient
 
keepAlive(Transaction) - Method in class ZKBasedRevisionManager
 
KERBEROS_KEYTAB - Static variable in class AppConfig
 
KERBEROS_PRINCIPAL - Static variable in class AppConfig
 
KERBEROS_SECRET - Static variable in class AppConfig
 
kerberosKeytab() - Method in class AppConfig
 
kerberosPrincipal() - Method in class AppConfig
 
kerberosSecret() - Method in class AppConfig
 
killJob(JobID) - Method in class TempletonJobTracker
Kill a job.

L

LauncherDelegator - Class in org.apache.hcatalog.templeton
The helper class for all the Templeton delegator classes that launch child jobs.
LauncherDelegator(AppConfig) - Constructor for class LauncherDelegator
 
LazyHCatRecord - Class in org.apache.hcatalog.data
An implementation of HCatRecord that wraps an Object returned by a SerDe and an ObjectInspector.
LazyHCatRecord(Object, ObjectInspector) - Constructor for class LazyHCatRecord
 
LIB_JARS_NAME - Static variable in class AppConfig
 
libJars() - Method in class AppConfig
 
linesTerminatedBy - Variable in class TableDesc.RowFormatDesc
 
LIST - Static variable in class DataType
 
listColumns(String, String, String) - Method in class HcatDelegator
Return a json description of the columns.
listColumns(String, String) - Method in class Server
List the columns in an hcat table.
listDatabaseNamesByPattern(String) - Method in class HCatClient
Get all existing databases that match the given pattern.
listDatabaseNamesByPattern(String) - Method in class HCatClientHMSImpl
 
listDatabases(String, String) - Method in class HcatDelegator
Return a json "show databases like".
listDatabases(String) - Method in class Server
List all databases, or those that match a pattern.
ListDelegator - Class in org.apache.hcatalog.templeton
List jobs owned by a user.
ListDelegator(AppConfig) - Constructor for class ListDelegator
 
listPartitions(String, String, String) - Method in class HcatDelegator
Return a json description of the partitions.
listPartitions(String, String) - Method in class Server
List all the partitions in an hcat table.
listPartitionsByFilter(String, String, String) - Method in class HCatClient
List partitions by filter.
listPartitionsByFilter(String, String, String) - Method in class HCatClientHMSImpl
 
listTableNamesByPattern(String, String) - Method in class HCatClient
Returns all existing tables from the specified database which match the given pattern.
listTableNamesByPattern(String, String) - Method in class HCatClientHMSImpl
 
listTableProperties(String, String, String) - Method in class HcatDelegator
List the table properties.
listTableProperties(String, String) - Method in class Server
List all the properties on an hcat table.
listTables(String, String, String) - Method in class HcatDelegator
Return a json "show table like".
listTables(String, String) - Method in class Server
List all the tables in an hcat database.
loadConfig(String[]) - Method in class Main
 
location(String) - Method in class HCatCreateDBDesc.Builder
Location.
location(String) - Method in class HCatCreateTableDesc.Builder
Location.
location - Variable in class DatabaseDesc
 
location - Variable in class PartitionDesc
 
location - Variable in class TableDesc
 
location - Variable in class TableLikeDesc
 
lock() - Method in class WriteLock
Attempts to acquire the exclusive write lock returning whether or not it was acquired.
lockAcquired() - Method in interface LockListener
call back called when the lock is acquired
LockListener - Interface in org.apache.hcatalog.hbase.snapshot.lock
This class has two methods which are call back methods when a lock is acquired and when the lock is released.
lockReleased() - Method in interface LockListener
call back called when the lock is released.
LOG - Static variable in class LazyHCatRecord
 
LONG - Static variable in class DataType
 

M

main(String[]) - Static method in class HCatCli
 
main(String[]) - Static method in class JavaAction
 
Main - Class in org.apache.hcatalog.templeton
The main executable that starts up and runs the Server.
Main(String[]) - Constructor for class Main
 
main(String[]) - Static method in class Main
 
main(String[]) - Static method in class TempletonControllerJob
 
makeAuthFilter() - Method in class Main
 
makeFieldZnode(TempletonStorage.Type, String, String) - Method in class ZooKeeperStorage
Make a ZK path to the named field.
makeHar(JobContext, String, String) - Static method in class HarOutputCommitterPostProcessor
Creates a har file from the contents of a given directory, using that as root.
makeJerseyConfig() - Method in class Main
 
makeLauncherArgs(AppConfig, String, String, List<String>) - Method in class LauncherDelegator
 
makeOverrideClasspath(AppConfig) - Static method in class LauncherDelegator
Create the override classpath, which will be added to HADOOP_CLASSPATH at runtime by the controller job.
makeStatus(TempletonJobTracker, JobID, String, JobState) - Static method in class StatusDelegator
 
makeStatus(TempletonJobTracker, JobID, JobState) - Static method in class StatusDelegator
 
makeTrackingJobZnode(String) - Method in class JobStateTracker
Make a ZK path to an existing tracking node
makeTrackingZnode() - Method in class JobStateTracker
Make a ZK path to a new tracking node
makeZnode(TempletonStorage.Type, String) - Method in class ZooKeeperStorage
Make a ZK path to job
MAP - Static variable in class DataType
 
mapKeysTerminatedBy - Variable in class TableDesc.RowFormatDesc
 
mapReduceJar(String, String, String, String, List<String>, List<String>, String, String) - Method in class Server
Run a MapReduce Jar job.
mapReduceStreaming(List<String>, String, String, String, List<String>, List<String>, List<String>, List<String>, String, String) - Method in class Server
Run a MapReduce Streaming job.
mapToJson(Object) - Static method in class JsonBuilder
Convert a map to a json string.
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class HCatClient
Mark partition for event.
markPartitionForEvent(String, String, Map<String, String>, PartitionEventType) - Method in class HCatClientHMSImpl
 
maxage - Static variable in class HDFSCleanup
 
maxage - Static variable in class ZooKeeperCleanup
 
MaxByteArrayOutputStream - Class in org.apache.hcatalog.templeton
An output stream that will only accept the first N bytes of data.
MaxByteArrayOutputStream(int) - Constructor for class MaxByteArrayOutputStream
Create.
metaDataMap - Static variable in class StoreFamilyRevision
 
metaDataMap - Static variable in class StoreFamilyRevisionList
 
MultiOutputFormat - Class in org.apache.hcatalog.mapreduce
The MultiOutputFormat class simplifies writing output data to multiple outputs.
MultiOutputFormat() - Constructor for class MultiOutputFormat
 
MultiOutputFormat.JobConfigurer - Class in org.apache.hcatalog.mapreduce
Class that supports configuration of the job for multiple output formats.
MultiOutputFormat.MultiOutputCommitter - Class in org.apache.hcatalog.mapreduce
 
MultiOutputFormat.MultiOutputCommitter(TaskAttemptContext) - Constructor for class MultiOutputFormat.MultiOutputCommitter
 

N

name - Variable in class ColumnDesc
 
name - Variable in class TableDesc.SerdeDesc
 
name - Variable in class TablePropertyDesc
 
needsTaskCommit(TaskAttemptContext) - Method in class MultiOutputFormat.MultiOutputCommitter
 
newTable - Variable in class TableLikeDesc
 
nextKeyValue() - Method in class RCFileMapReduceRecordReader
 
nextKeyValue() - Method in class NullRecordReader
 
NotAuthorizedException - Class in org.apache.hcatalog.templeton
Simple "user not found" type exception.
NotAuthorizedException(String) - Constructor for class NotAuthorizedException
 
NotFoundException - Exception in org.apache.hcatalog.templeton.tool
Simple not found exception.
NotFoundException(String) - Constructor for exception NotFoundException
 
NotificationListener - Class in org.apache.hcatalog.listener
Implementation of MetaStoreEventListener It sends message on two type of topics.
NotificationListener(Configuration) - Constructor for class NotificationListener
Create message bus connection and session in constructor.
NULL - Static variable in class DataType
 
NullRecordReader - Class in org.apache.hcatalog.templeton.tool
An empty record reader.
NullRecordReader() - Constructor for class NullRecordReader
 
NullSplit - Class in org.apache.hcatalog.templeton.tool
An empty splitter.
NullSplit() - Constructor for class NullSplit
 
numberOfBuckets - Variable in class TableDesc.ClusteredByDesc
 

O

ObjectNotFoundException - Exception in org.apache.hcatalog.api
This exception is thrown when a Database, Table or Partition specified in an HCatalog query is not found.
ObjectNotFoundException(String, Throwable) - Constructor for exception ObjectNotFoundException
 
onAddPartition(AddPartitionEvent) - Method in class NotificationListener
 
onAlterPartition(AlterPartitionEvent) - Method in class NotificationListener
 
onAlterTable(AlterTableEvent) - Method in class NotificationListener
 
onCreateDatabase(CreateDatabaseEvent) - Method in class NotificationListener
 
onCreateTable(CreateTableEvent) - Method in class NotificationListener
 
onDropDatabase(DropDatabaseEvent) - Method in class NotificationListener
 
onDropPartition(DropPartitionEvent) - Method in class NotificationListener
Send dropped partition notifications.
onDropTable(DropTableEvent) - Method in class NotificationListener
Send dropped table notifications.
onLoadPartitionDone(LoadPartitionDoneEvent) - Method in class NotificationListener
 
open() - Method in interface RevisionManager
Opens the revision manager.
open() - Method in class RevisionManagerEndpoint
 
open() - Method in class RevisionManagerEndpointClient
 
open() - Method in class ZKBasedRevisionManager
Open a ZooKeeper connection
open(String, Configuration) - Method in class SecureProxySupport
Create the delegation token.
openStorage(Configuration) - Method in class HDFSStorage
 
openStorage(Configuration) - Method in interface TempletonStorage
For storage methods that require a connection, this is a hint that it's time to open a connection.
openStorage(Configuration) - Method in class ZooKeeperStorage
 
order - Variable in class TableDesc.ClusterSortOrderDesc
 
org.apache.hadoop.mapred - package org.apache.hadoop.mapred
 
org.apache.hcatalog.api - package org.apache.hcatalog.api
 
org.apache.hcatalog.cli - package org.apache.hcatalog.cli
 
org.apache.hcatalog.cli.SemanticAnalysis - package org.apache.hcatalog.cli.SemanticAnalysis
 
org.apache.hcatalog.common - package org.apache.hcatalog.common
 
org.apache.hcatalog.data - package org.apache.hcatalog.data
 
org.apache.hcatalog.data.schema - package org.apache.hcatalog.data.schema
 
org.apache.hcatalog.data.transfer - package org.apache.hcatalog.data.transfer
 
org.apache.hcatalog.data.transfer.impl - package org.apache.hcatalog.data.transfer.impl
 
org.apache.hcatalog.data.transfer.state - package org.apache.hcatalog.data.transfer.state
 
org.apache.hcatalog.har - package org.apache.hcatalog.har
 
org.apache.hcatalog.hbase - package org.apache.hcatalog.hbase
 
org.apache.hcatalog.hbase.snapshot - package org.apache.hcatalog.hbase.snapshot
Provides a revision manager for data stored in HBase that can be used to implement repeatable reads.
org.apache.hcatalog.hbase.snapshot.lock - package org.apache.hcatalog.hbase.snapshot.lock
 
org.apache.hcatalog.hbase.snapshot.transaction.thrift - package org.apache.hcatalog.hbase.snapshot.transaction.thrift
 
org.apache.hcatalog.listener - package org.apache.hcatalog.listener
 
org.apache.hcatalog.mapreduce - package org.apache.hcatalog.mapreduce
 
org.apache.hcatalog.oozie - package org.apache.hcatalog.oozie
 
org.apache.hcatalog.pig - package org.apache.hcatalog.pig
 
org.apache.hcatalog.rcfile - package org.apache.hcatalog.rcfile
 
org.apache.hcatalog.security - package org.apache.hcatalog.security
 
org.apache.hcatalog.shims - package org.apache.hcatalog.shims
 
org.apache.hcatalog.storagehandler - package org.apache.hcatalog.storagehandler
 
org.apache.hcatalog.templeton - package org.apache.hcatalog.templeton
 
org.apache.hcatalog.templeton.tool - package org.apache.hcatalog.templeton.tool
 
OUTPUT_CONFS_TO_SAVE - Static variable in class HCatConstants
 
OutputJobInfo - Class in org.apache.hcatalog.mapreduce
The class used to serialize and store the output related information
OVERHEAD_PATH - Static variable in class HDFSStorage
 
overhead_path - Variable in class ZooKeeperStorage
 
OVERRIDE_CLASSPATH - Static variable in class TempletonControllerJob
 
OVERRIDE_JARS_ENABLED - Static variable in class AppConfig
 
OVERRIDE_JARS_NAME - Static variable in class AppConfig
 
overrideJars() - Method in class AppConfig
 
overrideJarsString() - Method in class AppConfig
 

P

Pair<T,U> - Class in org.apache.hcatalog.data
Copy of C++ STL pair container.
Pair(T, U) - Constructor for class Pair
 
params - Variable in class SimpleWebException
 
parentId - Variable in class QueueStatusBean
 
partCols(List<HCatFieldSchema>) - Method in class HCatCreateTableDesc.Builder
Partition cols.
PartInfo - Class in org.apache.hcatalog.mapreduce
The Class used to serialize the partition information read from the metadata server that maps to a partition.
PartInfo(HCatSchema, HCatStorageHandler, String, Properties, Map<String, String>, HCatTableInfo) - Constructor for class PartInfo
Instantiates a new hcat partition info.
partition - Variable in class PartitionDesc
 
PartitionDesc - Class in org.apache.hcatalog.templeton
A description of the partition to create.
PartitionDesc() - Constructor for class PartitionDesc
 
partitionedBy - Variable in class TableDesc
 
PathUtil - Class in org.apache.hcatalog.hbase.snapshot
The PathUtil class is a utility class to provide information about various znode paths.
PathUtil() - Constructor for class PathUtil
 
percentComplete - Variable in class QueueStatusBean
 
permissions - Variable in class GroupPermissionsDesc
 
pig(String, String, List<String>, String, String, String) - Method in class Server
Run a Pig job.
PIG_ARCHIVE_NAME - Static variable in class AppConfig
 
PIG_COMPLETE - Static variable in class TempletonUtils
 
PIG_ID - Static variable in class TempletonUtils
 
PIG_PATH_NAME - Static variable in class AppConfig
 
pigArchive() - Method in class AppConfig
 
PigDelegator - Class in org.apache.hcatalog.templeton
Submit a Pig job.
PigDelegator(AppConfig) - Constructor for class PigDelegator
 
pigPath() - Method in class AppConfig
 
PORT - Static variable in class AppConfig
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class HCatSemanticAnalyzer
 
postAnalyze(HiveSemanticAnalyzerHookContext, List<Task<? extends Serializable>>) - Method in class HCatSemanticAnalyzerBase
 
preAnalyze(HiveSemanticAnalyzerHookContext, ASTNode) - Method in class HCatSemanticAnalyzer
 
preCreateTable(Table) - Method in class HBaseHCatStorageHandler
 
preDropTable(Table) - Method in class HBaseHCatStorageHandler
 
prepareRead() - Method in class HCatReader
This should be called at master node to obtain ReaderContext which then should be serialized and sent to slave nodes.
prepareRead() - Method in class HCatInputFormatReader
 
prepareWrite() - Method in class HCatWriter
External system should invoke this method exactly once from a master node.
prepareWrite() - Method in class HCatOutputFormatWriter
 
profile - Variable in class QueueStatusBean
 
properties - Variable in class DatabaseDesc
 
properties - Variable in class TableDesc.SerdeDesc
 
properties - Variable in class TableDesc.StoredByDesc
 
put(String, Object) - Method in class JsonBuilder
Add a non-null value to the map.

Q

QueueException - Class in org.apache.hcatalog.templeton
Unable to queue the job
QueueException(String) - Constructor for class QueueException
 
QueueStatusBean - Class in org.apache.hcatalog.templeton
QueueStatusBean - The results of an exec call.
QueueStatusBean() - Constructor for class QueueStatusBean
 
QueueStatusBean(JobState, JobStatus, JobProfile) - Constructor for class QueueStatusBean
Create a new QueueStatusBean

R

RCFileMapReduceInputFormat<K extends LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hcatalog.rcfile
 
RCFileMapReduceInputFormat() - Constructor for class RCFileMapReduceInputFormat
 
RCFileMapReduceOutputFormat - Class in org.apache.hcatalog.rcfile
The RC file input format using new Hadoop mapreduce APIs.
RCFileMapReduceOutputFormat() - Constructor for class RCFileMapReduceOutputFormat
 
RCFileMapReduceRecordReader<K extends LongWritable,V extends BytesRefArrayWritable> - Class in org.apache.hcatalog.rcfile
 
RCFileMapReduceRecordReader() - Constructor for class RCFileMapReduceRecordReader
 
re - Variable in class HCatReader
 
read() - Method in class HCatReader
This should be called at slave nodes to read HCatRecords
read() - Method in class HCatInputFormatReader
 
read(TProtocol) - Method in class StoreFamilyRevision
 
read(TProtocol) - Method in class StoreFamilyRevisionList
 
readDatum(DataInput) - Static method in class ReaderWriter
 
ReadEntity - Class in org.apache.hcatalog.data.transfer
 
ReadEntity.Builder - Class in org.apache.hcatalog.data.transfer
This class should be used to build ReadEntity.
ReadEntity.Builder() - Constructor for class ReadEntity.Builder
 
ReaderContext - Class in org.apache.hcatalog.data.transfer
This class will contain information of different InputSplit obtained at master node and configuration.
ReaderContext() - Constructor for class ReaderContext
 
ReaderWriter - Class in org.apache.hcatalog.data
 
ReaderWriter() - Constructor for class ReaderWriter
 
readExternal(ObjectInput) - Method in class ReaderContext
 
readExternal(ObjectInput) - Method in class WriterContext
 
readFields(DataInput) - Method in class DefaultHCatRecord
 
readFields(DataInput) - Method in class LazyHCatRecord
 
readFields(DataInput) - Method in class HCatSplit
 
readFields(DataInput) - Method in class NullSplit
 
registerAuthProvider(String, String) - Static method in class StorageDelegationAuthorizationProvider
 
registerJob(String, String, String) - Method in class LauncherDelegator
 
relativeToAbsolutePath(String, Path) - Method in class HCatLoader
 
remove(int) - Method in class DefaultHCatRecord
 
remove(int) - Method in class HCatRecord
 
remove(int) - Method in class LazyHCatRecord
 
remove(HCatFieldSchema) - Method in class HCatSchema
 
remove(String) - Method in class JsonBuilder
Remove a value from the map.
renameTable(String, String, String) - Method in class HCatClient
Renames a table.
renameTable(String, String, String) - Method in class HCatClientHMSImpl
 
renameTable(String, String, String, String, String, String) - Method in class HcatDelegator
Rename a table.
renameTable(String, String, String, String, String) - Method in class Server
Rename an hcat table.
renewDelegationToken(String) - Method in class HCatClient
Renew delegation token.
renewDelegationToken(String) - Method in class HCatClientHMSImpl
 
requestFormats() - Method in class Server
Check the supported request formats of this server.
revision - Variable in class StoreFamilyRevision
 
REVISION_MGR_ENDPOINT_IMPL_CLASS - Static variable in class RMConstants
 
REVISION_MGR_IMPL_CLASS - Static variable in class RevisionManagerFactory
 
revisionList - Variable in class StoreFamilyRevisionList
 
RevisionManager - Interface in org.apache.hcatalog.hbase.snapshot
This interface provides APIs for implementing revision management.
RevisionManagerConfiguration - Class in org.apache.hcatalog.hbase.snapshot
 
RevisionManagerConfiguration() - Constructor for class RevisionManagerConfiguration
 
RevisionManagerEndpoint - Class in org.apache.hcatalog.hbase.snapshot
Implementation of RevisionManager as HBase RPC endpoint.
RevisionManagerEndpoint() - Constructor for class RevisionManagerEndpoint
 
RevisionManagerEndpointClient - Class in org.apache.hcatalog.hbase.snapshot
This class is nothing but a delegate for the enclosed proxy, which is created upon setting the configuration.
RevisionManagerEndpointClient() - Constructor for class RevisionManagerEndpointClient
 
RevisionManagerFactory - Class in org.apache.hcatalog.hbase.snapshot
Utility to instantiate the revision manager (not a true factory actually).
RevisionManagerFactory() - Constructor for class RevisionManagerFactory
 
RevisionManagerProtocol - Interface in org.apache.hcatalog.hbase.snapshot
Interface marker to implement RevisionManager as Coprocessor.
RMConstants - Class in org.apache.hcatalog.hbase.snapshot
 
RMConstants() - Constructor for class RMConstants
 
rollbackCreateTable(Table) - Method in class HBaseHCatStorageHandler
 
rollbackDropTable(Table) - Method in class HBaseHCatStorageHandler
 
rowFormat - Variable in class TableDesc.StorageFormatDesc
 
run(String) - Method in class HCatDriver
 
run(String) - Method in class CompleteDelegator
 
run(String, String) - Method in class DeleteDelegator
 
run(String, List<String>, Map<String, String>) - Method in interface ExecService
 
run(String, List<String>, Map<String, String>) - Method in class ExecServiceImpl
Run the program synchronously as the given user.
run(String, String, boolean, String, String) - Method in class HcatDelegator
Run the local hcat executable.
run(String, String, String, List<String>, String, String, String) - Method in class HiveDelegator
 
run(String, String, String, String, String, List<String>, List<String>, String, String, String) - Method in class JarDelegator
 
run(String) - Method in class ListDelegator
 
run() - Method in class Main
 
run(String, String, String, List<String>, String, String, String, String) - Method in class PigDelegator
 
run(String, String) - Method in class StatusDelegator
 
run(String, List<String>, String, String, String, List<String>, List<String>, List<String>, List<String>, String, String, String) - Method in class StreamingDelegator
 
run() - Method in class HDFSCleanup
Run the cleanup loop.
run() - Method in class TempletonControllerJob.KeepAlive
 
run(Mapper<NullWritable, NullWritable, Text, Text>.Context) - Method in class TempletonControllerJob.LaunchMapper
 
run(String[]) - Method in class TempletonControllerJob
Enqueue the job and print out the job id for later collection.
run() - Method in class TempletonControllerJob.Watcher
 
run(List<String>, List<String>, Map<String, String>) - Method in class TrivialExecService
 
run() - Method in class ZooKeeperCleanup
Run the cleanup loop.
runAs - Variable in class LauncherDelegator
 
runServer(int) - Method in class Main
 
runUnlimited(String, List<String>, Map<String, String>) - Method in interface ExecService
 
runUnlimited(String, List<String>, Map<String, String>) - Method in class ExecServiceImpl
Run the program synchronously as the given user.

S

saveField(TempletonStorage.Type, String, String, String) - Method in class HDFSStorage
 
saveField(TempletonStorage.Type, String, String, String) - Method in interface TempletonStorage
Save a single key/value pair for a specific job id.
saveField(TempletonStorage.Type, String, String, String) - Method in class ZooKeeperStorage
 
second - Variable in class Pair
 
SecureProxySupport - Class in org.apache.hcatalog.templeton
Helper class to run jobs using Kerberos security.
SecureProxySupport() - Constructor for class SecureProxySupport
 
send(Object, String, String) - Method in class NotificationListener
 
sendReport - Variable in class TempletonControllerJob.KeepAlive
 
SEQUENCEFILE_INPUT - Static variable in class HCatConstants
 
SEQUENCEFILE_OUTPUT - Static variable in class HCatConstants
 
serde - Variable in class TableDesc.RowFormatDesc
 
serialize(Serializable) - Static method in class HCatUtil
 
serialize(Object, ObjectInspector) - Method in class HCatRecordSerDe
The purpose of the serialize method is to turn an object-representation with a provided ObjectInspector into a Writable format, which the underlying layer can then use to write out.
serialize(Object, ObjectInspector) - Method in class JsonSerDe
Given an object and object inspector pair, traverse the object and generate a Text representation of the object.
serializeField(Object, ObjectInspector) - Static method in class HCatRecordSerDe
Return underlying Java Object from an object-representation that is readable by a provided ObjectInspector.
Server - Class in org.apache.hcatalog.templeton
The Templeton Web API server.
Server() - Constructor for class Server
 
SERVLET_PATH - Static variable in class Main
 
session - Variable in class NotificationListener
 
set(int, Object) - Method in class DefaultHCatRecord
 
set(String, HCatSchema, Object) - Method in class DefaultHCatRecord
 
set(String, HCatSchema, Object) - Method in class HCatRecord
 
set(int, Object) - Method in interface HCatRecordable
Sets the field at the specified index.
set(int, Object) - Method in class LazyHCatRecord
 
set(String, HCatSchema, Object) - Method in class LazyHCatRecord
 
setAuthenticator(HiveAuthenticationProvider) - Method in class StorageDelegationAuthorizationProvider
 
setBoolean(String, HCatSchema, Boolean) - Method in class HCatRecord
 
setByte(String, HCatSchema, Byte) - Method in class HCatRecord
 
setByteArray(String, HCatSchema, byte[]) - Method in class HCatRecord
 
setCallback(String) - Method in class JobState
 
setChildId(String) - Method in class JobState
 
setChildren(String) - Method in class JobState
Save a comma-separated list of jobids that are children of this job.
setChildren(List<JobState>) - Method in class JobState
Set the list of child jobs of this job
setColumnNumber(Configuration, int) - Static method in class RCFileMapReduceOutputFormat
Set number of columns into the given configuration.
setCompleteStatus(String) - Method in class JobState
 
setConf(Configuration) - Method in enum HCatContext
Use the given configuration for optional behavior.
setConf(Configuration) - Method in class ReaderContext
 
setConf(Configuration) - Method in class WriterContext
 
setConf(Configuration) - Method in class HBaseHCatStorageHandler
 
setConf(Configuration) - Method in class RevisionManagerEndpointClient
 
setConf(Configuration) - Method in class FosterStorageHandler
 
setConf(Configuration) - Method in class HCatStorageHandler
 
setConf(Configuration) - Method in class HdfsAuthorizationProvider
 
setConf(Configuration) - Method in class StorageDelegationAuthorizationProvider
 
setCreated(long) - Method in class JobState
 
setDouble(String, HCatSchema, Double) - Method in class HCatRecord
 
setDynamicPartitioningKeys(List<String>) - Method in class OutputJobInfo
Sets the list of dynamic partitioning keys used for outputting without specifying all the keys
setEnabled(boolean) - Method in class HarOutputCommitterPostProcessor
 
setExitValue(long) - Method in class JobState
 
setField(String, String) - Method in class JobState
Store a String field from the store.
setFieldValue(StoreFamilyRevision._Fields, Object) - Method in class StoreFamilyRevision
 
setFieldValue(StoreFamilyRevisionList._Fields, Object) - Method in class StoreFamilyRevisionList
 
setFilter(String) - Method in class HCatInputFormat
Set a filter on the input table.
setFloat(String, HCatSchema, Float) - Method in class HCatRecord
 
setHarRequested(boolean) - Method in class OutputJobInfo
Sets whether or not hadoop archiving has been requested for this job
setIfClass(String) - Method in class StorerInfo
 
setInput(Job, InputJobInfo) - Static method in class HCatInputFormat
Deprecated. as of release 0.5, and will be removed in a future release
setInput(Configuration, InputJobInfo) - Static method in class HCatInputFormat
Deprecated. as of release 0.5, and will be removed in a future release
setInput(Job, String, String) - Static method in class HCatInputFormat
See HCatInputFormat.setInput(org.apache.hadoop.conf.Configuration, String, String)
setInput(Configuration, String, String) - Static method in class HCatInputFormat
Set inputs to use for the job.
setInputSplits(List<InputSplit>) - Method in class ReaderContext
 
setInteger(String, HCatSchema, Integer) - Method in class HCatRecord
 
setList(String, HCatSchema, List<?>) - Method in class HCatRecord
 
setLocation(String) - Method in class OutputJobInfo
 
setLocation(String, Job) - Method in class HCatLoader
 
setLockListener(LockListener) - Method in class WriteLock
register a different call back listener
setLong(String, HCatSchema, Long) - Method in class HCatRecord
 
setLongField(String, long) - Method in class JobState
Store a long field.
setMap(String, HCatSchema, Map<?, ?>) - Method in class HCatRecord
 
setMaximumDynamicPartitions(int) - Method in class OutputJobInfo
Set maximum number of allowable dynamic partitions
setNotifiedTime(long) - Method in class JobState
 
setOutput(Job, OutputJobInfo) - Static method in class HCatOutputFormat
 
setOutput(Configuration, Credentials, OutputJobInfo) - Static method in class HCatOutputFormat
Set the information about the output to write for the job.
setOutputSchema(Job, HCatSchema) - Static method in class HCatBaseInputFormat
Set the schema for the HCatRecord data returned by HCatInputFormat.
setOutputSchema(HCatSchema) - Method in class OutputJobInfo
 
setPartDetails(OutputJobInfo, HCatSchema, Map<String, String>) - Static method in class HCatBaseOutputFormat
 
setPartitionFilter(Expression) - Method in class HCatLoader
 
setPartitionValues(Map<String, String>) - Method in class PartInfo
Sets the partition values.
setPercentComplete(String) - Method in class JobState
 
setPosOfDynPartCols(List<Integer>) - Method in class OutputJobInfo
 
setPosOfPartCols(List<Integer>) - Method in class OutputJobInfo
 
setProperties(Properties) - Method in class HCatInputFormat
Set properties for the input format.
setProperties(Properties) - Method in class StorerInfo
 
setRevision(long) - Method in class StoreFamilyRevision
 
setRevisionIsSet(boolean) - Method in class StoreFamilyRevision
 
setRevisionList(List<StoreFamilyRevision>) - Method in class StoreFamilyRevisionList
 
setRevisionListIsSet(boolean) - Method in class StoreFamilyRevisionList
 
setSchema(Job, HCatSchema) - Static method in class HCatOutputFormat
 
setSchema(Configuration, HCatSchema) - Static method in class HCatOutputFormat
Set the schema for the data being written out to the partition.
setShort(String, HCatSchema, Short) - Method in class HCatRecord
 
setStoreLocation(String, Job) - Method in class HCatStorer
 
setString(String, HCatSchema, String) - Method in class HCatRecord
 
setStruct(String, HCatSchema, List<? extends Object>) - Method in class HCatRecord
 
setTimestamp(long) - Method in class StoreFamilyRevision
 
setTimestampIsSet(boolean) - Method in class StoreFamilyRevision
 
setupJob(JobContext) - Method in class MultiOutputFormat.MultiOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class MultiOutputFormat.MultiOutputCommitter
 
setUser(String) - Method in class JobState
 
SHORT - Static variable in class DataType
 
showQueueId(String) - Method in class Server
Return the status of the jobid.
showQueueList() - Method in class Server
Return all the known job ids for this user.
SimpleExceptionMapper - Class in org.apache.hcatalog.templeton
Map our exceptions to the Jersey response.
SimpleExceptionMapper() - Constructor for class SimpleExceptionMapper
 
SimpleWebException - Class in org.apache.hcatalog.templeton
Simple exception that will return a json error payload if thrown from a JAX web server.
SimpleWebException(int, String) - Constructor for class SimpleWebException
 
SimpleWebException(int, String, Map<String, Object>) - Constructor for class SimpleWebException
 
SingleInputFormat - Class in org.apache.hcatalog.templeton.tool
An empty InputFormat.
SingleInputFormat() - Constructor for class SingleInputFormat
 
size() - Method in class DefaultHCatRecord
 
size() - Method in interface HCatRecordable
Gets the size of the hcat record.
size() - Method in class LazyHCatRecord
 
size() - Method in class HCatSchema
 
sortCols(ArrayList<Order>) - Method in class HCatCreateTableDesc.Builder
Sort cols.
sortedBy - Variable in class TableDesc.ClusteredByDesc
 
sp - Variable in class HCatReader
 
sp - Variable in class HCatWriter
 
start(CoprocessorEnvironment) - Method in class RevisionManagerEndpoint
 
startCleanup() - Method in class AppConfig
 
startCleanup(Configuration) - Method in class HDFSStorage
 
startCleanup(Configuration) - Method in interface TempletonStorage
Start the cleanup process for this storage type.
startCleanup(Configuration) - Method in class ZooKeeperStorage
 
startInstance(Configuration) - Static method in class HDFSCleanup
 
startInstance(Configuration) - Static method in class ZooKeeperCleanup
 
startJob(Mapper<NullWritable, NullWritable, Text, Text>.Context, String, String) - Method in class TempletonControllerJob.LaunchMapper
 
statement - Variable in class HcatException
 
StateProvider - Interface in org.apache.hcatalog.data.transfer.state
If external system wants to communicate any state to slaves, they can do so via this interface.
status - Variable in class CompleteBean
 
status - Variable in class QueueStatusBean
 
status() - Method in class Server
Check the status of this server.
STATUS_OK - Static variable in class Server
The status message.
StatusDelegator - Class in org.apache.hcatalog.templeton
Fetch the status of a given job id in the queue.
StatusDelegator(AppConfig) - Constructor for class StatusDelegator
 
STATUSDIR_NAME - Static variable in class TempletonControllerJob
 
stderr - Variable in class ExecBean
 
STDERR_FNAME - Static variable in class TempletonControllerJob
 
stdout - Variable in class ExecBean
 
STDOUT_FNAME - Static variable in class TempletonControllerJob
 
stop(CoprocessorEnvironment) - Method in class RevisionManagerEndpoint
 
STORAGE_CLASS - Static variable in interface TempletonStorage
 
storage_root - Variable in class HDFSStorage
 
STORAGE_ROOT - Static variable in interface TempletonStorage
 
storage_root - Variable in class ZooKeeperStorage
 
StorageDelegationAuthorizationProvider - Class in org.apache.hcatalog.security
A HiveAuthorizationProvider which delegates the authorization requests to the underlying AuthorizationProviders obtained from the StorageHandler.
StorageDelegationAuthorizationProvider() - Constructor for class StorageDelegationAuthorizationProvider
 
storageHandler(String) - Method in class HCatCreateTableDesc.Builder
Storage handler.
storedAs - Variable in class TableDesc.StorageFormatDesc
 
storedBy - Variable in class TableDesc.StorageFormatDesc
 
StoreFamilyRevision - Class in org.apache.hcatalog.hbase.snapshot.transaction.thrift
 
StoreFamilyRevision() - Constructor for class StoreFamilyRevision
 
StoreFamilyRevision(long, long) - Constructor for class StoreFamilyRevision
 
StoreFamilyRevision(StoreFamilyRevision) - Constructor for class StoreFamilyRevision
Performs a deep copy on other.
StoreFamilyRevision._Fields - Enum in org.apache.hcatalog.hbase.snapshot.transaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
StoreFamilyRevisionList - Class in org.apache.hcatalog.hbase.snapshot.transaction.thrift
 
StoreFamilyRevisionList() - Constructor for class StoreFamilyRevisionList
 
StoreFamilyRevisionList(List<StoreFamilyRevision>) - Constructor for class StoreFamilyRevisionList
 
StoreFamilyRevisionList(StoreFamilyRevisionList) - Constructor for class StoreFamilyRevisionList
Performs a deep copy on other.
StoreFamilyRevisionList._Fields - Enum in org.apache.hcatalog.hbase.snapshot.transaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
StorerInfo - Class in org.apache.hcatalog.mapreduce
Information about the storer to use for writing the data.
StorerInfo(String, String, String, String, Properties) - Constructor for class StorerInfo
Initialize the storer information.
storeSchema(ResourceSchema, String, Job) - Method in class HCatStorer
 
STREAMING_JAR_NAME - Static variable in class AppConfig
 
StreamingDelegator - Class in org.apache.hcatalog.templeton
Submit a streaming job to the MapReduce queue.
StreamingDelegator(AppConfig) - Constructor for class StreamingDelegator
 
streamingJar() - Method in class AppConfig
 
STRING - Static variable in class DataType
 
StringToJobID(String) - Static method in class StatusDelegator
A version of JobID.forName with our app specific error handling.
STRUCT - Static variable in class DataType
 
SUPPORTED_FORMATS - Static variable in class Server
The list of supported return formats.
SUPPORTED_VERSIONS - Static variable in class Server
The list of supported api versions.
SYSENV_HADOOP_TOKEN_FILE_LOCATION - Static variable in class HCatConstants
 

T

table - Variable in class TableDesc
 
TableDesc - Class in org.apache.hcatalog.templeton
A description of the table to create.
TableDesc() - Constructor for class TableDesc
Create a new TableDesc
TableDesc.ClusteredByDesc - Class in org.apache.hcatalog.templeton
How to cluster the table.
TableDesc.ClusteredByDesc() - Constructor for class TableDesc.ClusteredByDesc
 
TableDesc.ClusterSortOrderDesc - Class in org.apache.hcatalog.templeton
The clustered sort order.
TableDesc.ClusterSortOrderDesc() - Constructor for class TableDesc.ClusterSortOrderDesc
 
TableDesc.ClusterSortOrderDesc(String, TableDesc.SortDirectionDesc) - Constructor for class TableDesc.ClusterSortOrderDesc
 
TableDesc.RowFormatDesc - Class in org.apache.hcatalog.templeton
The Row Format.
TableDesc.RowFormatDesc() - Constructor for class TableDesc.RowFormatDesc
 
TableDesc.SerdeDesc - Class in org.apache.hcatalog.templeton
The SERDE Row Format.
TableDesc.SerdeDesc() - Constructor for class TableDesc.SerdeDesc
 
TableDesc.SortDirectionDesc - Enum in org.apache.hcatalog.templeton
Ther ASC or DESC sort order.
TableDesc.StorageFormatDesc - Class in org.apache.hcatalog.templeton
The storage format.
TableDesc.StorageFormatDesc() - Constructor for class TableDesc.StorageFormatDesc
 
TableDesc.StoredByDesc - Class in org.apache.hcatalog.templeton
How to store the table.
TableDesc.StoredByDesc() - Constructor for class TableDesc.StoredByDesc
 
TableLikeDesc - Class in org.apache.hcatalog.templeton
A description of the table to create that's like another table.
TableLikeDesc() - Constructor for class TableLikeDesc
 
tableProperties - Variable in class TableDesc
 
TablePropertyDesc - Class in org.apache.hcatalog.templeton
A description of a table property.
TablePropertyDesc() - Constructor for class TablePropertyDesc
 
TableSnapshot - Class in org.apache.hcatalog.hbase.snapshot
The snapshot for a table and a list of column families.
TableSnapshot(String, Map<String, Long>, long) - Constructor for class TableSnapshot
 
tblProps(Map<String, String>) - Method in class HCatCreateTableDesc.Builder
Tbl props.
TEMP_DIR_NAME - Static variable in class FosterStorageHandler
The directory under which data is initially written for a non partitioned table
TEMPLETON_CONF_FILENAMES - Static variable in class AppConfig
 
TEMPLETON_CONTROLLER_MR_CHILD_OPTS - Static variable in class AppConfig
 
TEMPLETON_HOME_VAR - Static variable in class AppConfig
 
TEMPLETON_JAR_NAME - Static variable in class AppConfig
 
TempletonControllerJob - Class in org.apache.hcatalog.templeton.tool
A Map Reduce job that will start another job.
TempletonControllerJob() - Constructor for class TempletonControllerJob
 
TempletonControllerJob.KeepAlive - Class in org.apache.hcatalog.templeton.tool
 
TempletonControllerJob.KeepAlive(Counter) - Constructor for class TempletonControllerJob.KeepAlive
 
TempletonControllerJob.LaunchMapper - Class in org.apache.hcatalog.templeton.tool
 
TempletonControllerJob.LaunchMapper() - Constructor for class TempletonControllerJob.LaunchMapper
 
TempletonControllerJob.Watcher - Class in org.apache.hcatalog.templeton.tool
 
TempletonControllerJob.Watcher(Configuration, JobID, InputStream, String, String) - Constructor for class TempletonControllerJob.Watcher
 
TempletonDelegator - Class in org.apache.hcatalog.templeton
The helper class for all the Templeton delegator classes.
TempletonDelegator(AppConfig) - Constructor for class TempletonDelegator
 
templetonJar() - Method in class AppConfig
 
TempletonJobTracker - Class in org.apache.hadoop.mapred
 
TempletonJobTracker(InetSocketAddress, Configuration) - Constructor for class TempletonJobTracker
Create a connection to the Job Tracker.
TempletonStorage - Interface in org.apache.hcatalog.templeton.tool
An interface to handle different Templeton storage methods, including ZooKeeper and HDFS.
TempletonStorage.Type - Enum in org.apache.hcatalog.templeton.tool
 
TempletonUtils - Class in org.apache.hcatalog.templeton.tool
General utility methods.
TempletonUtils() - Constructor for class TempletonUtils
 
timestamp - Variable in class StoreFamilyRevision
 
TOKEN_FILE_ARG_PLACEHOLDER - Static variable in class TempletonControllerJob
 
toResponse(Exception) - Method in class CatchallExceptionMapper
 
toResponse(SimpleWebException) - Method in class SimpleExceptionMapper
 
toString() - Method in class HCatAddPartitionDesc
 
toString() - Method in class HCatCreateDBDesc
 
toString() - Method in class HCatCreateTableDesc
 
toString() - Method in class HCatDatabase
 
toString() - Method in class HCatPartition
 
toString() - Method in class HCatTable
 
toString() - Method in exception HCatException
 
toString() - Method in class DefaultHCatRecord
 
toString() - Method in class LazyHCatRecord
 
toString() - Method in class Pair
 
toString() - Method in class HCatFieldSchema
 
toString() - Method in class HCatSchema
 
toString() - Method in class HCatTableSnapshot
 
toString() - Method in class FamilyRevision
 
toString() - Method in class ZNodeName
 
toString() - Method in class TableSnapshot
 
toString() - Method in class StoreFamilyRevision
 
toString() - Method in class StoreFamilyRevisionList
 
toString() - Method in class Transaction
 
toString() - Method in class ColumnDesc
 
toString() - Method in class DatabaseDesc
 
toString() - Method in class ExecBean
 
toString() - Method in class PartitionDesc
 
toString() - Method in class TableDesc.ClusteredByDesc
 
toString() - Method in class TableDesc.ClusterSortOrderDesc
 
toString() - Method in class TableDesc
 
toString() - Method in class TableLikeDesc
 
toString() - Method in class TablePropertyDesc
 
TRACKINGDIR - Static variable in class ZooKeeperStorage
 
Transaction - Class in org.apache.hcatalog.hbase.snapshot
This class is responsible for storing information related to transactions.
TrivialExecService - Class in org.apache.hcatalog.templeton.tool
Execute a local program.
TrivialExecService() - Constructor for class TrivialExecService
 
type - Variable in class ColumnDesc
 

U

UgiFactory - Class in org.apache.hcatalog.templeton
 
UgiFactory() - Constructor for class UgiFactory
 
unlock() - Method in class WriteLock
Removes the lock or associated znode if you no longer require the lock.
unsetRevision() - Method in class StoreFamilyRevision
 
unsetRevisionList() - Method in class StoreFamilyRevisionList
 
unsetTimestamp() - Method in class StoreFamilyRevision
 
updateTableSchema(String, String, List<HCatFieldSchema>) - Method in class HCatClient
Updates the Table's column schema to the specified definition.
updateTableSchema(String, String, List<HCatFieldSchema>) - Method in class HCatClientHMSImpl
 
usage() - Method in class Main
 
user - Variable in class QueueStatusBean
 

V

validate() - Method in class StoreFamilyRevision
 
validate() - Method in class StoreFamilyRevisionList
 
validateExecuteBitPresentIfReadOrWrite(FsAction) - Static method in class HCatUtil
Ensure that read or write permissions are not granted without also granting execute permissions.
validateMorePermissive(FsAction, FsAction) - Static method in class HCatUtil
Test if the first FsAction is more permissive than the second.
validatePartitionSchema(Table, HCatSchema) - Static method in class HCatUtil
Validate partition schema, checks if the column types match between the partition and the existing table schema.
validateProgram(String) - Method in class ExecServiceImpl
Given a program name, lookup the fully qualified path.
value - Variable in class TablePropertyDesc
 
valueOf(String) - Static method in enum HCatClient.DropDBMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum ErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum HCatContext
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum HCatFieldSchema.Category
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum HCatFieldSchema.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum StoreFamilyRevision._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum StoreFamilyRevisionList._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum HCatHadoopShims.PropertyName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum TableDesc.SortDirectionDesc
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum TempletonStorage.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum HCatClient.DropDBMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum ErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum HCatContext
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum HCatFieldSchema.Category
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum HCatFieldSchema.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum StoreFamilyRevision._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum StoreFamilyRevisionList._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum HCatHadoopShims.PropertyName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum TableDesc.SortDirectionDesc
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum TempletonStorage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
verifyDdlParam(String, String) - Method in class Server
Verify that the parameter exists and is a simple DDL identifier name.
verifyParam(String, String) - Method in class Server
Verify that the parameter exists.
verifyParam(List<String>, String) - Method in class Server
Verify that the parameter exists.
verifyUser() - Method in class Server
Verify that we have a valid user.
VERSION - Static variable in interface RevisionManager
Version property required by HBase to use this interface for CoprocessorProtocol / RPC.
VERSION - Static variable in class Server
 
version() - Method in class Server
Check the version(s) supported by this server.

W

WadlConfig - Class in org.apache.hcatalog.templeton
Simple class that incorporates javadoc information into the wadl produced by jersey.
WadlConfig() - Constructor for class WadlConfig
 
WATCHER_TIMEOUT_SECS - Static variable in class TempletonControllerJob
 
we - Variable in class HCatWriter
 
wh - Variable in class HdfsAuthorizationProvider
 
withDatabase(String) - Method in class ReadEntity.Builder
 
withDatabase(String) - Method in class WriteEntity.Builder
 
withFilter(String) - Method in class ReadEntity.Builder
 
withKeyType(HCatFieldSchema.Type) - Method in class HCatSchemaUtils.MapBuilder
 
withPartition(Map<String, String>) - Method in class ReadEntity.Builder
 
withPartition(Map<String, String>) - Method in class WriteEntity.Builder
 
withRegion(String) - Method in class ReadEntity.Builder
 
withRegion(String) - Method in class WriteEntity.Builder
 
withTable(String) - Method in class ReadEntity.Builder
 
withTable(String) - Method in class WriteEntity.Builder
 
withValueSchema(HCatSchema) - Method in class HCatSchemaUtils.MapBuilder
 
write(DataOutput) - Method in class DefaultHCatRecord
 
write(DataOutput) - Method in class LazyHCatRecord
 
write(Iterator<HCatRecord>) - Method in class HCatWriter
This method should be used at slave needs to perform writes.
write(Iterator<HCatRecord>) - Method in class HCatOutputFormatWriter
 
write(TProtocol) - Method in class StoreFamilyRevision
 
write(TProtocol) - Method in class StoreFamilyRevisionList
 
write(DataOutput) - Method in class HCatSplit
 
write(String, K, V, TaskInputOutputContext) - Static method in class MultiOutputFormat
Write the output key and value using the OutputFormat defined by the alias.
write(int) - Method in class MaxByteArrayOutputStream
Writes the specified byte to this byte array output stream.
write(byte[], int, int) - Method in class MaxByteArrayOutputStream
Writes len bytes from the specified byte array starting at offset off to this byte array output stream.
write(DataOutput) - Method in class NullSplit
 
WRITE_TRANSACTION_TIMEOUT - Static variable in class RMConstants
 
writeDatum(DataOutput, Object) - Static method in class ReaderWriter
 
WriteEntity - Class in org.apache.hcatalog.data.transfer
 
WriteEntity.Builder - Class in org.apache.hcatalog.data.transfer
This class should be used to build WriteEntity.
WriteEntity.Builder() - Constructor for class WriteEntity.Builder
 
writeExternal(ObjectOutput) - Method in class ReaderContext
 
writeExternal(ObjectOutput) - Method in class WriterContext
 
WriteLock - Class in org.apache.hcatalog.hbase.snapshot.lock
A protocol to implement an exclusive write lock or to elect a leader.
WriteLock(ZooKeeper, String, List<ACL>) - Constructor for class WriteLock
zookeeper contructor for writelock
WriteLock(ZooKeeper, String, List<ACL>, LockListener) - Constructor for class WriteLock
zookeeper contructor for writelock with callback
WriterContext - Class in org.apache.hcatalog.data.transfer
This contains information obtained at master node to help prepare slave nodes for writer.
WriterContext() - Constructor for class WriterContext
 

X

xequals(Object, Object) - Static method in class GroupPermissionsDesc
 
xequals(boolean, boolean) - Static method in class GroupPermissionsDesc
 
xequals(int, int) - Static method in class GroupPermissionsDesc
 
xequals(char, char) - Static method in class GroupPermissionsDesc
 

Z

ZK_CLEANUP_INTERVAL - Static variable in class ZooKeeperCleanup
 
ZK_CLEANUP_MAX_AGE - Static variable in class ZooKeeperCleanup
 
ZK_HOSTS - Static variable in class ZooKeeperStorage
 
ZK_SESSION_TIMEOUT - Static variable in class ZooKeeperStorage
 
ZKBasedRevisionManager - Class in org.apache.hcatalog.hbase.snapshot
The service for providing revision management to Hbase tables.
ZKBasedRevisionManager() - Constructor for class ZKBasedRevisionManager
 
zkCleanupInterval() - Method in class AppConfig
 
zkHosts() - Method in class AppConfig
 
zkMaxAge() - Method in class AppConfig
 
zkOpen(String, int) - Static method in class ZooKeeperStorage
Open a ZooKeeper connection for the JobState.
zkOpen(Configuration) - Static method in class ZooKeeperStorage
Open a ZooKeeper connection for the JobState.
zkSessionTimeout() - Method in class AppConfig
 
ZNodeName - Class in org.apache.hcatalog.hbase.snapshot.lock
Represents an ephemeral znode name which has an ordered sequence number and can be sorted in order This class has been used as-is from the zookeeper 3.4.0 recipes with a change in package name.
ZNodeName(String) - Constructor for class ZNodeName
 
ZOOKEEPER_DATADIR - Static variable in class RMConstants
 
ZOOKEEPER_HOSTLIST - Static variable in class RMConstants
 
ZooKeeperCleanup - Class in org.apache.hcatalog.templeton.tool
This does periodic cleanup
ZooKeeperOperation - Interface in org.apache.hcatalog.hbase.snapshot.lock
A callback object which can be used for implementing retry-able operations in the ProtocolSupport class This class has been used as-is from the zookeeper 3.4.0 with change in the package name .
ZooKeeperStorage - Class in org.apache.hcatalog.templeton.tool
A storage implementation based on storing everything in ZooKeeper.
ZooKeeperStorage() - Constructor for class ZooKeeperStorage
 

A B C D E F G H I J K L M N O P Q R S T U V W X Z