Class CombineFns.ComposedCombineFnWithContext<DataT>
- All Implemented Interfaces:
Serializable,CombineFnBase.GlobalCombineFn<DataT,,Object[], CombineFns.CoCombineResult> CombineWithContext.RequiresContextInternal,HasDisplayData
- Enclosing class:
CombineFns
CombineWithContext.CombineFnWithContext that applies multiple CombineFnWithContexts.
For each CombineWithContext.CombineFnWithContext it extracts inputs from DataT with the
extractInputFn and combines them, and then it outputs each combined value with a TupleTag to a CombineFns.CoCombineResult.
- See Also:
-
Method Summary
Modifier and TypeMethodDescriptionObject[]addInput(Object[] accumulator, DataT value, CombineWithContext.Context c) Adds the given input value to the given accumulator, returning the new accumulator value.Object[]compact(Object[] accumulator, CombineWithContext.Context c) Returns an accumulator that represents the same logical value as the input accumulator, but may have a more compact representation.Object[]Returns a new, mutable accumulator value, representing the accumulation of zero input values.extractOutput(Object[] accumulator, CombineWithContext.Context c) Returns the output value that is the result of combining all the input values represented by the given accumulator.TypeVariable<?> Returns theTypeVariableofAccumT.getAccumulatorCoder(CoderRegistry registry, Coder<DataT> dataCoder) Returns theCoderto use for accumulatorAccumTvalues, or null if it is not able to be inferred.getDefaultOutputCoder(CoderRegistry registry, Coder<DataT> inputCoder) Returns theCoderto use by default for outputOutputTvalues, or null if it is not able to be inferred.Returns the error message for not supported default values in Combine.globally().TypeVariable<?> Returns theTypeVariableofInputT.TypeVariable<?> Returns theTypeVariableofOutputT.Object[]mergeAccumulators(Iterable<Object[]> accumulators, CombineWithContext.Context c) Returns an accumulator representing the accumulation of all the input values accumulated in the merging accumulators.voidpopulateDisplayData(DisplayData.Builder builder) Register display data for the given transform or component.<InputT,OutputT>
CombineFns.ComposedCombineFnWithContext<DataT> with(SimpleFunction<DataT, InputT> extractInputFn, Coder<InputT> combineInputCoder, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT> globalCombineFn, TupleTag<OutputT> outputTag) Returns aCombineFns.ComposedCombineFnWithContextwith an additionalCombineFnBase.GlobalCombineFn.<InputT,OutputT>
CombineFns.ComposedCombineFnWithContext<DataT> with(SimpleFunction<DataT, InputT> extractInputFn, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT> globalCombineFn, TupleTag<OutputT> outputTag) Returns aCombineFns.ComposedCombineFnWithContextwith an additionalCombineFnBase.GlobalCombineFn.Methods inherited from class org.apache.beam.sdk.transforms.CombineWithContext.CombineFnWithContext
apply, defaultValue
-
Method Details
-
with
public <InputT,OutputT> CombineFns.ComposedCombineFnWithContext<DataT> with(SimpleFunction<DataT, InputT> extractInputFn, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT> globalCombineFn, TupleTag<OutputT> outputTag) Returns aCombineFns.ComposedCombineFnWithContextwith an additionalCombineFnBase.GlobalCombineFn. -
with
public <InputT,OutputT> CombineFns.ComposedCombineFnWithContext<DataT> with(SimpleFunction<DataT, InputT> extractInputFn, Coder<InputT> combineInputCoder, CombineFnBase.GlobalCombineFn<InputT, ?, OutputT> globalCombineFn, TupleTag<OutputT> outputTag) Returns aCombineFns.ComposedCombineFnWithContextwith an additionalCombineFnBase.GlobalCombineFn. -
createAccumulator
Description copied from class:CombineWithContext.CombineFnWithContextReturns a new, mutable accumulator value, representing the accumulation of zero input values.It is equivalent to
Combine.CombineFn.createAccumulator(), but it has additional access toCombineWithContext.Context.- Specified by:
createAccumulatorin classCombineWithContext.CombineFnWithContext<DataT,Object[], CombineFns.CoCombineResult>
-
addInput
Description copied from class:CombineWithContext.CombineFnWithContextAdds the given input value to the given accumulator, returning the new accumulator value.It is equivalent to
Combine.CombineFn.addInput(AccumT, InputT), but it has additional access toCombineWithContext.Context.- Specified by:
addInputin classCombineWithContext.CombineFnWithContext<DataT,Object[], CombineFns.CoCombineResult>
-
mergeAccumulators
Description copied from class:CombineWithContext.CombineFnWithContextReturns an accumulator representing the accumulation of all the input values accumulated in the merging accumulators.It is equivalent to
Combine.CombineFn.mergeAccumulators(java.lang.Iterable<AccumT>), but it has additional access toCombineWithContext.Context.- Specified by:
mergeAccumulatorsin classCombineWithContext.CombineFnWithContext<DataT,Object[], CombineFns.CoCombineResult>
-
extractOutput
Description copied from class:CombineWithContext.CombineFnWithContextReturns the output value that is the result of combining all the input values represented by the given accumulator.It is equivalent to
Combine.CombineFn.extractOutput(AccumT), but it has additional access toCombineWithContext.Context.- Specified by:
extractOutputin classCombineWithContext.CombineFnWithContext<DataT,Object[], CombineFns.CoCombineResult>
-
compact
Description copied from class:CombineWithContext.CombineFnWithContextReturns an accumulator that represents the same logical value as the input accumulator, but may have a more compact representation.It is equivalent to
Combine.CombineFn.compact(AccumT), but it has additional access toCombineWithContext.Context.- Overrides:
compactin classCombineWithContext.CombineFnWithContext<DataT,Object[], CombineFns.CoCombineResult>
-
getAccumulatorCoder
public Coder<Object[]> getAccumulatorCoder(CoderRegistry registry, Coder<DataT> dataCoder) throws CannotProvideCoderException Description copied from interface:CombineFnBase.GlobalCombineFnReturns theCoderto use for accumulatorAccumTvalues, or null if it is not able to be inferred.By default, uses the knowledge of the
Coderbeing used forInputTvalues and the enclosingPipeline'sCoderRegistryto try to infer the Coder forAccumTvalues.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.
- Specified by:
getAccumulatorCoderin interfaceCombineFnBase.GlobalCombineFn<DataT,Object[], CombineFns.CoCombineResult> - Throws:
CannotProvideCoderException
-
populateDisplayData
Register display data for the given transform or component.populateDisplayData(DisplayData.Builder)is invoked by Pipeline runners to collect display data viaDisplayData.from(HasDisplayData). Implementations may callsuper.populateDisplayData(builder)in order to register display data in the current namespace, but should otherwise usesubcomponent.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.
- Specified by:
populateDisplayDatain interfaceHasDisplayData- Parameters:
builder- The builder to populate with display data.- See Also:
-
getDefaultOutputCoder
public Coder<CombineFns.CoCombineResult> getDefaultOutputCoder(CoderRegistry registry, Coder<DataT> inputCoder) throws CannotProvideCoderException Description copied from interface:CombineFnBase.GlobalCombineFnReturns theCoderto use by default for outputOutputTvalues, or null if it is not able to be inferred.By default, uses the knowledge of the
Coderbeing used for inputInputTvalues and the enclosingPipeline'sCoderRegistryto try to infer the Coder forOutputTvalues.- Specified by:
getDefaultOutputCoderin interfaceCombineFnBase.GlobalCombineFn<InputT,AccumT, OutputT> - Throws:
CannotProvideCoderException
-
getIncompatibleGlobalWindowErrorMessage
Description copied from interface:CombineFnBase.GlobalCombineFnReturns the error message for not supported default values in Combine.globally().- Specified by:
getIncompatibleGlobalWindowErrorMessagein interfaceCombineFnBase.GlobalCombineFn<InputT,AccumT, OutputT>
-
getInputTVariable
Returns theTypeVariableofInputT. -
getAccumTVariable
Returns theTypeVariableofAccumT. -
getOutputTVariable
Returns theTypeVariableofOutputT.
-