public abstract class AddPartitionMessage extends EventMessage
EventMessage.EventTypeeventType| Modifier | Constructor and Description |
|---|---|
protected |
AddPartitionMessage() |
| Modifier and Type | Method and Description |
|---|---|
EventMessage |
checkValid()
Class invariant.
|
abstract Iterable<PartitionFiles> |
getPartitionFilesIter()
Get iterable of partition name and file lists created as a result of this DDL operation
|
abstract Iterable<org.apache.hadoop.hive.metastore.api.Partition> |
getPartitionObjs() |
abstract List<Map<String,String>> |
getPartitions()
Getter for list of partitions added.
|
abstract String |
getTable()
Getter for name of table (where partitions are added).
|
abstract org.apache.hadoop.hive.metastore.api.Table |
getTableObj() |
abstract String |
getTableType() |
getDB, getEventType, getServer, getServicePrincipal, getTimestamppublic abstract String getTable()
public abstract String getTableType()
public abstract org.apache.hadoop.hive.metastore.api.Table getTableObj()
throws Exception
Exceptionpublic abstract List<Map<String,String>> getPartitions()
public abstract Iterable<org.apache.hadoop.hive.metastore.api.Partition> getPartitionObjs() throws Exception
Exceptionpublic EventMessage checkValid()
EventMessagecheckValid in class EventMessagepublic abstract Iterable<PartitionFiles> getPartitionFilesIter()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.