public class DynamicPartitionPruner extends Object
| Constructor and Description |
|---|
DynamicPartitionPruner(org.apache.tez.runtime.api.InputInitializerContext context,
MapWork work,
org.apache.hadoop.mapred.JobConf jobConf) |
| Modifier and Type | Method and Description |
|---|---|
void |
addEvent(org.apache.tez.runtime.api.events.InputInitializerEvent event) |
protected org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner.SourceInfo |
createSourceInfo(TableDesc t,
ExprNodeDesc partKeyExpr,
String columnName,
org.apache.hadoop.mapred.JobConf jobConf) |
BlockingQueue<Object> |
getQueue() |
protected String |
processPayload(ByteBuffer payload,
String sourceName) |
void |
processVertex(String name) |
void |
prune() |
protected void |
prunePartitionSingleSource(String source,
org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner.SourceInfo si) |
public DynamicPartitionPruner(org.apache.tez.runtime.api.InputInitializerContext context,
MapWork work,
org.apache.hadoop.mapred.JobConf jobConf)
throws SerDeException
SerDeExceptionpublic void prune()
throws SerDeException,
IOException,
InterruptedException,
HiveException
public BlockingQueue<Object> getQueue()
protected void prunePartitionSingleSource(String source, org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner.SourceInfo si) throws HiveException
HiveExceptionprotected org.apache.hadoop.hive.ql.exec.tez.DynamicPartitionPruner.SourceInfo createSourceInfo(TableDesc t, ExprNodeDesc partKeyExpr, String columnName, org.apache.hadoop.mapred.JobConf jobConf) throws SerDeException
SerDeExceptionprotected String processPayload(ByteBuffer payload, String sourceName) throws SerDeException, IOException
SerDeExceptionIOExceptionpublic void addEvent(org.apache.tez.runtime.api.events.InputInitializerEvent event)
public void processVertex(String name)
Copyright © 2017 The Apache Software Foundation. All rights reserved.