Class SparkSideInputReader
java.lang.Object
org.apache.beam.runners.spark.structuredstreaming.translation.batch.functions.SparkSideInputReader
- All Implemented Interfaces:
 Serializable,org.apache.beam.runners.core.SideInputReader
public class SparkSideInputReader
extends Object
implements org.apache.beam.runners.core.SideInputReader, Serializable
SideInputReader using broadcasted 
SideInputValues.- See Also:
 
- 
Method Summary
Modifier and TypeMethodDescription<T> booleancontains(PCollectionView<T> view) static org.apache.beam.runners.core.SideInputReadercreate(Map<String, org.apache.spark.broadcast.Broadcast<SideInputValues<?>>> sideInputs) Creates aSideInputReaderfor Spark from a map of PCollectionViewtag idsand the corresponding broadcastedSideInputValues.static org.apache.beam.runners.core.SideInputReaderempty()<T> @Nullable Tget(PCollectionView<T> view, BoundedWindow window) booleanisEmpty()static voidvalidateMaterializations(Iterable<PCollectionView<?>> views)  
- 
Method Details
- 
empty
public static org.apache.beam.runners.core.SideInputReader empty() - 
create
public static org.apache.beam.runners.core.SideInputReader create(Map<String, org.apache.spark.broadcast.Broadcast<SideInputValues<?>>> sideInputs) Creates aSideInputReaderfor Spark from a map of PCollectionViewtag idsand the corresponding broadcastedSideInputValues.Note, the materialization of respective
PCollectionViewsshould be validated ahead of time before any costly creation and broadcast ofSideInputValues. - 
validateMaterializations
 - 
get
- Specified by:
 getin interfaceorg.apache.beam.runners.core.SideInputReader
 - 
contains
- Specified by:
 containsin interfaceorg.apache.beam.runners.core.SideInputReader
 - 
isEmpty
public boolean isEmpty()- Specified by:
 isEmptyin interfaceorg.apache.beam.runners.core.SideInputReader
 
 -