public class AccumuloRangeGenerator extends Object implements NodeProcessor
| Constructor and Description |
|---|
AccumuloRangeGenerator(AccumuloPredicateHandler predicateHandler,
HiveAccumuloRowIdColumnMapping rowIdMapping,
String hiveRowIdColumnName) |
| Modifier and Type | Method and Description |
|---|---|
protected org.apache.hadoop.io.Text |
getBinaryValue(ConstantObjectInspector objInspector)
Attempts to construct the binary value from the given inspector.
|
protected org.apache.accumulo.core.data.Range |
getColumnOpConstantRange(Class<? extends CompareOp> opClz,
org.apache.hadoop.io.Text constText) |
protected org.apache.accumulo.core.data.Range |
getConstantOpColumnRange(Class<? extends CompareOp> opClz,
org.apache.hadoop.io.Text constText) |
protected org.apache.hadoop.io.Text |
getUtf8Value(ConstantObjectInspector objInspector) |
Object |
process(Node nd,
Stack<Node> stack,
NodeProcessorCtx procCtx,
Object... nodeOutputs)
Generic process for all ops that don't have specific implementations.
|
protected Object |
processAndOpNode(Node nd,
Object[] nodeOutputs) |
protected Object |
processExpression(ExprNodeGenericFuncDesc func,
Object[] nodeOutputs) |
protected Object |
processOrOpNode(Node nd,
Object[] nodeOutputs) |
public AccumuloRangeGenerator(AccumuloPredicateHandler predicateHandler, HiveAccumuloRowIdColumnMapping rowIdMapping, String hiveRowIdColumnName)
public Object process(Node nd, Stack<Node> stack, NodeProcessorCtx procCtx, Object... nodeOutputs) throws SemanticException
NodeProcessorprocess in interface NodeProcessornd - operator to processprocCtx - operator processor contextnodeOutputs - A variable argument list of outputs from other nodes in the walkSemanticExceptionprotected Object processExpression(ExprNodeGenericFuncDesc func, Object[] nodeOutputs) throws SemanticException
SemanticExceptionprotected org.apache.accumulo.core.data.Range getConstantOpColumnRange(Class<? extends CompareOp> opClz, org.apache.hadoop.io.Text constText)
protected org.apache.accumulo.core.data.Range getColumnOpConstantRange(Class<? extends CompareOp> opClz, org.apache.hadoop.io.Text constText)
protected org.apache.hadoop.io.Text getUtf8Value(ConstantObjectInspector objInspector)
protected org.apache.hadoop.io.Text getBinaryValue(ConstantObjectInspector objInspector) throws IOException
IOExceptionCopyright © 2017 The Apache Software Foundation. All rights reserved.