public class JSONAddPartitionMessage extends AddPartitionMessage
EventMessage.EventTypeeventType| Constructor and Description |
|---|
JSONAddPartitionMessage()
Default Constructor.
|
JSONAddPartitionMessage(String server,
String servicePrincipal,
org.apache.hadoop.hive.metastore.api.Table tableObj,
Iterator<org.apache.hadoop.hive.metastore.api.Partition> partitionsIterator,
Iterator<PartitionFiles> partitionFileIter,
Long timestamp)
Note that we get an Iterator rather than an Iterable here: so we can only walk thru the list once
|
| Modifier and Type | Method and Description |
|---|---|
String |
getDB()
Getter for the name of the Database on which the Metastore operation is done.
|
Iterable<PartitionFiles> |
getPartitionFilesIter()
Get iterable of partition name and file lists created as a result of this DDL operation
|
List<String> |
getPartitionListJson() |
Iterable<org.apache.hadoop.hive.metastore.api.Partition> |
getPartitionObjs() |
List<Map<String,String>> |
getPartitions()
Getter for list of partitions added.
|
String |
getServer()
Getter for HCatalog Server's URL.
|
String |
getServicePrincipal()
Getter for the Kerberos principal of the HCatalog service.
|
String |
getTable()
Getter for name of table (where partitions are added).
|
org.apache.hadoop.hive.metastore.api.Table |
getTableObj() |
String |
getTableObjJson() |
String |
getTableType() |
Long |
getTimestamp()
Getter for the timestamp associated with the operation.
|
String |
toString() |
checkValidgetEventTypepublic JSONAddPartitionMessage()
public JSONAddPartitionMessage(String server, String servicePrincipal, org.apache.hadoop.hive.metastore.api.Table tableObj, Iterator<org.apache.hadoop.hive.metastore.api.Partition> partitionsIterator, Iterator<PartitionFiles> partitionFileIter, Long timestamp)
public String getServer()
EventMessagegetServer in class EventMessagepublic String getServicePrincipal()
EventMessagegetServicePrincipal in class EventMessagepublic String getDB()
EventMessagegetDB in class EventMessagepublic String getTable()
AddPartitionMessagegetTable in class AddPartitionMessagepublic String getTableType()
getTableType in class AddPartitionMessagepublic org.apache.hadoop.hive.metastore.api.Table getTableObj()
throws Exception
getTableObj in class AddPartitionMessageExceptionpublic Long getTimestamp()
EventMessagegetTimestamp in class EventMessagepublic List<Map<String,String>> getPartitions()
AddPartitionMessagegetPartitions in class AddPartitionMessagepublic Iterable<org.apache.hadoop.hive.metastore.api.Partition> getPartitionObjs() throws Exception
getPartitionObjs in class AddPartitionMessageExceptionpublic String getTableObjJson()
public Iterable<PartitionFiles> getPartitionFilesIter()
AddPartitionMessagegetPartitionFilesIter in class AddPartitionMessageCopyright © 2019 The Apache Software Foundation. All Rights Reserved.