Package | Description |
---|---|
org.apache.flink.api.java.functions | |
org.apache.flink.api.java.sampling |
Modifier and Type | Method and Description |
---|---|
void |
SampleInPartition.mapPartition(Iterable<T> values,
org.apache.flink.util.Collector<IntermediateSampleData<T>> out) |
void |
SampleInCoordinator.reduce(Iterable<IntermediateSampleData<T>> values,
org.apache.flink.util.Collector<T> out) |
Modifier and Type | Field and Description |
---|---|
protected Iterator<IntermediateSampleData<T>> |
DistributedRandomSampler.emptyIntermediateIterable |
Modifier and Type | Method and Description |
---|---|
Iterator<IntermediateSampleData<T>> |
ReservoirSamplerWithReplacement.sampleInPartition(Iterator<T> input) |
Iterator<IntermediateSampleData<T>> |
ReservoirSamplerWithoutReplacement.sampleInPartition(Iterator<T> input) |
abstract Iterator<IntermediateSampleData<T>> |
DistributedRandomSampler.sampleInPartition(Iterator<T> input)
Sample algorithm for the first phase.
|
Modifier and Type | Method and Description |
---|---|
int |
IntermediateSampleData.compareTo(IntermediateSampleData<T> other) |
Modifier and Type | Method and Description |
---|---|
Iterator<T> |
DistributedRandomSampler.sampleInCoordinator(Iterator<IntermediateSampleData<T>> input)
Sample algorithm for the second phase.
|
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.