public class HBaseLookupFunction
extends org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
构造器和说明 |
---|
HBaseLookupFunction(org.apache.hadoop.conf.Configuration configuration,
String hTableName,
HBaseTableSchema hbaseTableSchema) |
限定符和类型 | 方法和说明 |
---|---|
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
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
在类中 org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
public void open(org.apache.flink.table.functions.FunctionContext context)
open
在类中 org.apache.flink.table.functions.UserDefinedFunction
public void close()
close
在类中 org.apache.flink.table.functions.UserDefinedFunction
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.