public class HBaseLookupFunction
extends org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
Constructor and Description |
---|
HBaseLookupFunction(org.apache.hadoop.conf.Configuration configuration,
String hTableName,
HBaseTableSchema hbaseTableSchema) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
void |
eval(Object rowKey)
The invoke entry point of lookup function.
|
org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.types.Row> |
getResultType() |
void |
open(org.apache.flink.table.functions.FunctionContext context) |
collect, getKind, getParameterTypes, setCollector
functionIdentifier, toString
public HBaseLookupFunction(org.apache.hadoop.conf.Configuration configuration, String hTableName, HBaseTableSchema hbaseTableSchema)
public void eval(Object rowKey) throws IOException
rowKey
- the lookup key. Currently only support single rowkey.IOException
public org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.types.Row> getResultType()
getResultType
in class org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
public void open(org.apache.flink.table.functions.FunctionContext context)
open
in class org.apache.flink.table.functions.UserDefinedFunction
public void close()
close
in class org.apache.flink.table.functions.UserDefinedFunction
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.