Package | Description |
---|---|
org.apache.flink.table.runtime.functions.aggregate | |
org.apache.flink.table.runtime.functions.aggregate.hyperloglog |
Modifier and Type | Method and Description |
---|---|
HllBuffer |
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction.createAccumulator() |
Modifier and Type | Method and Description |
---|---|
void |
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction.accumulate(HllBuffer buffer,
Object input) |
Long |
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction.getValue(HllBuffer buffer) |
void |
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction.merge(HllBuffer buffer,
Iterable<HllBuffer> it) |
void |
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction.resetAccumulator(HllBuffer buffer) |
Modifier and Type | Method and Description |
---|---|
void |
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction.merge(HllBuffer buffer,
Iterable<HllBuffer> it) |
Modifier and Type | Method and Description |
---|---|
void |
HyperLogLogPlusPlus.merge(HllBuffer buffer1,
HllBuffer buffer2)
Merge the HLL buffers by iterating through the registers in both buffers and select the
maximum number of leading zeros for each register.
|
long |
HyperLogLogPlusPlus.query(HllBuffer buffer)
Compute the HyperLogLog estimate.
|
void |
HyperLogLogPlusPlus.updateByHashcode(HllBuffer buffer,
long hash)
Update the HLL++ buffer.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.