public static class Combine.IterableCombineFn<V> extends Combine.CombineFn<V,java.util.List<V>,V> implements org.apache.beam.sdk.util.NameUtils.NameOverride
SerializableFunction from Iterable<V>s
 to Vs into a simple Combine.CombineFn over Vs.
 Used in the implementation of convenience methods like
 Combine.globally(SerializableFunction),
 Combine.perKey(SerializableFunction), and
 Combine.groupedValues(SerializableFunction).
| Modifier and Type | Method and Description | 
|---|---|
java.util.List<V> | 
addInput(java.util.List<V> accumulator,
        V input)
Adds the given input value to the given accumulator, returning the
 new accumulator value. 
 | 
java.util.List<V> | 
compact(java.util.List<V> accumulator)
Returns an accumulator that represents the same logical value as the
 input accumulator, but may have a more compact representation. 
 | 
java.util.List<V> | 
createAccumulator()
Returns a new, mutable accumulator value, representing the accumulation of zero input values. 
 | 
V | 
extractOutput(java.util.List<V> accumulator)
Returns the output value that is the result of combining all
 the input values represented by the given accumulator. 
 | 
java.lang.reflect.TypeVariable<?> | 
getAccumTVariable()
Returns the  
TypeVariable of AccumT. | 
Coder<AccumT> | 
getAccumulatorCoder(CoderRegistry registry,
                   Coder<InputT> inputCoder)
Returns the  
Coder to use for accumulator AccumT
 values, or null if it is not able to be inferred. | 
Coder<OutputT> | 
getDefaultOutputCoder(CoderRegistry registry,
                     Coder<InputT> inputCoder)
Returns the  
Coder to use by default for output
 OutputT values, or null if it is not able to be inferred. | 
java.lang.String | 
getIncompatibleGlobalWindowErrorMessage()
Returns the error message for not supported default values in Combine.globally(). 
 | 
java.lang.reflect.TypeVariable<?> | 
getInputTVariable()
Returns the  
TypeVariable of InputT. | 
java.lang.String | 
getNameOverride()
Return the name to use for this instance. 
 | 
java.lang.reflect.TypeVariable<?> | 
getOutputTVariable()
Returns the  
TypeVariable of OutputT. | 
java.util.List<V> | 
mergeAccumulators(java.lang.Iterable<java.util.List<V>> accumulators)
Returns an accumulator representing the accumulation of all the
 input values accumulated in the merging accumulators. 
 | 
static <V> Combine.IterableCombineFn<V> | 
of(SerializableFunction<java.lang.Iterable<V>,V> combiner)
Returns a  
CombineFn that uses the given
 SerializableFunction to combine values. | 
static <V> Combine.IterableCombineFn<V> | 
of(SerializableFunction<java.lang.Iterable<V>,V> combiner,
  int bufferSize)
Returns a  
CombineFn that uses the given
 SerializableFunction to combine values,
 attempting to buffer at least bufferSize
 values between invocations. | 
void | 
populateDisplayData(DisplayData.Builder builder)
Register display data for the given transform or component. 
 | 
apply, defaultValue, getOutputTypepublic static <V> Combine.IterableCombineFn<V> of(SerializableFunction<java.lang.Iterable<V>,V> combiner)
CombineFn that uses the given
 SerializableFunction to combine values.public static <V> Combine.IterableCombineFn<V> of(SerializableFunction<java.lang.Iterable<V>,V> combiner, int bufferSize)
CombineFn that uses the given
 SerializableFunction to combine values,
 attempting to buffer at least bufferSize
 values between invocations.public java.util.List<V> createAccumulator()
Combine.CombineFncreateAccumulator in class Combine.CombineFn<V,java.util.List<V>,V>public java.util.List<V> addInput(java.util.List<V> accumulator, V input)
Combine.CombineFnFor efficiency, the input accumulator may be modified and returned.
addInput in class Combine.CombineFn<V,java.util.List<V>,V>public java.util.List<V> mergeAccumulators(java.lang.Iterable<java.util.List<V>> accumulators)
Combine.CombineFnMay modify any of the argument accumulators. May return a fresh accumulator, or may return one of the (modified) argument accumulators.
mergeAccumulators in class Combine.CombineFn<V,java.util.List<V>,V>public V extractOutput(java.util.List<V> accumulator)
Combine.CombineFnextractOutput in class Combine.CombineFn<V,java.util.List<V>,V>public java.util.List<V> compact(java.util.List<V> accumulator)
Combine.CombineFnFor most CombineFns this would be a no-op, but should be overridden by CombineFns that (for example) buffer up elements and combine them in batches.
For efficiency, the input accumulator may be modified and returned.
By default returns the original accumulator.
compact in class Combine.CombineFn<V,java.util.List<V>,V>public void populateDisplayData(DisplayData.Builder builder)
populateDisplayData(DisplayData.Builder) is invoked by Pipeline runners to collect
 display data via DisplayData.from(HasDisplayData). Implementations may call
 super.populateDisplayData(builder) in order to register display data in the current
 namespace, but should otherwise use subcomponent.populateDisplayData(builder) to use
 the namespace of the subcomponent.
 
By default, does not register any display data. Implementors may override this method to provide their own display data.
populateDisplayData in interface HasDisplayDatabuilder - The builder to populate with display data.HasDisplayDatapublic java.lang.String getNameOverride()
org.apache.beam.sdk.util.NameUtils.NameOverridegetNameOverride in interface org.apache.beam.sdk.util.NameUtils.NameOverridepublic Coder<AccumT> getAccumulatorCoder(CoderRegistry registry, Coder<InputT> inputCoder) throws CannotProvideCoderException
CombineFnBase.GlobalCombineFnCoder to use for accumulator AccumT
 values, or null if it is not able to be inferred.
 By default, uses the knowledge of the Coder being used
 for InputT values and the enclosing Pipeline's
 CoderRegistry to try to infer the Coder for AccumT
 values.
 
This is the Coder used to send data through a communication-intensive shuffle step, so a compact and efficient representation may have significant performance benefits.
getAccumulatorCoder in interface CombineFnBase.GlobalCombineFn<InputT,AccumT,OutputT>CannotProvideCoderExceptionpublic Coder<OutputT> getDefaultOutputCoder(CoderRegistry registry, Coder<InputT> inputCoder) throws CannotProvideCoderException
CombineFnBase.GlobalCombineFnCoder to use by default for output
 OutputT values, or null if it is not able to be inferred.
 By default, uses the knowledge of the Coder being
 used for input InputT values and the enclosing
 Pipeline's CoderRegistry to try to infer the
 Coder for OutputT values.
getDefaultOutputCoder in interface CombineFnBase.GlobalCombineFn<InputT,AccumT,OutputT>CannotProvideCoderExceptionpublic java.lang.String getIncompatibleGlobalWindowErrorMessage()
CombineFnBase.GlobalCombineFngetIncompatibleGlobalWindowErrorMessage in interface CombineFnBase.GlobalCombineFn<InputT,AccumT,OutputT>public java.lang.reflect.TypeVariable<?> getInputTVariable()
TypeVariable of InputT.public java.lang.reflect.TypeVariable<?> getAccumTVariable()
TypeVariable of AccumT.public java.lang.reflect.TypeVariable<?> getOutputTVariable()
TypeVariable of OutputT.