Class Join
java.lang.Object
org.apache.beam.sdk.schemas.transforms.Join
A transform that performs equijoins across two schema 
PCollections.
 This transform allows joins between two input PCollections simply by specifying the fields to
 join on. The resulting PCollection<Row> will have two fields named "lhs" and "rhs"
 respectively, each with the schema of the corresponding input PCollection.
 
For example, the following demonstrates joining two PCollections using a natural join on the "user" and "country" fields, where both the left-hand and the right-hand PCollections have fields with these names.
 PCollection<Row> joined = pCollection1.apply(Join.innerJoin(pCollection2).using("user", "country"));
 
 If the right-hand PCollection contains fields with different names to join against, you can specify them as follows:
PCollection<Row> joined = pCollection1.apply(Join.innerJoin(pCollection2)
       .on(FieldsEqual.left("user", "country").right("otherUser", "otherCountry")));
 
 Full outer joins, left outer joins, and right outer joins are also supported.
- 
Nested Class Summary
Nested ClassesModifier and TypeClassDescriptionstatic classPredicate object to specify fields to compare when doing an equi-join.static classImplementation class . - 
Field Summary
Fields - 
Constructor Summary
Constructors - 
Method Summary
Modifier and TypeMethodDescriptionstatic <LhsT,RhsT> 
Join.Impl<LhsT, RhsT> fullOuterJoin(PCollection<RhsT> rhs) Perform a full outer join.static <LhsT,RhsT> 
Join.Impl<LhsT, RhsT> innerBroadcastJoin(PCollection<RhsT> rhs) Perform an inner join, broadcasting the right side.static <LhsT,RhsT> 
Join.Impl<LhsT, RhsT> innerJoin(PCollection<RhsT> rhs) Perform an inner join.static <LhsT,RhsT> 
Join.Impl<LhsT, RhsT> leftOuterBroadcastJoin(PCollection<RhsT> rhs) Perform a left outer join, broadcasting the right side.static <LhsT,RhsT> 
Join.Impl<LhsT, RhsT> leftOuterJoin(PCollection<RhsT> rhs) Perform a left outer join.static <LhsT,RhsT> 
Join.Impl<LhsT, RhsT> rightOuterJoin(PCollection<RhsT> rhs) Perform a right outer join. 
- 
Field Details
- 
LHS_TAG
- See Also:
 
 - 
RHS_TAG
- See Also:
 
 
 - 
 - 
Constructor Details
- 
Join
public Join() 
 - 
 - 
Method Details
- 
innerJoin
Perform an inner join. - 
fullOuterJoin
Perform a full outer join. - 
leftOuterJoin
Perform a left outer join. - 
rightOuterJoin
Perform a right outer join. - 
innerBroadcastJoin
Perform an inner join, broadcasting the right side. - 
leftOuterBroadcastJoin
Perform a left outer join, broadcasting the right side. 
 -