public abstract class TwoInputNode extends OptimizerNode
OptimizerNode.UnclosedBranchDescriptor
Modifier and Type | Field and Description |
---|---|
protected DagConnection |
input1 |
protected DagConnection |
input2 |
protected FieldList |
keys1 |
protected FieldList |
keys2 |
cachedPlans, closedBranchingNodes, costWeight, estimatedNumRecords, estimatedOutputSize, hereJoinedBranches, id, MAX_DYNAMIC_PATH_COST_WEIGHT, onDynamicPath, openBranches, uniqueFields
Constructor and Description |
---|
TwoInputNode(DualInputOperator<?,?,?,?> operator)
Creates a new two input node for the optimizer plan, representing the given operator.
|
Modifier and Type | Method and Description |
---|---|
void |
accept(Visitor<OptimizerNode> visitor)
This method implements the visit of a depth-first graph traversing visitor.
|
protected void |
addLocalCandidates(Channel template1,
Channel template2,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
RequestedGlobalProperties rgps1,
RequestedGlobalProperties rgps2,
List<PlanNode> target,
OperatorDescriptorDual.LocalPropertiesPair[] validLocalCombinations,
CostEstimator estimator) |
void |
computeInterestingPropertiesForInputs(CostEstimator estimator)
Tells the node to compute the interesting properties for its inputs.
|
void |
computeUnclosedBranchStack()
This method causes the node to compute the description of open branches in its sub-plan.
|
List<PlanNode> |
getAlternativePlans(CostEstimator estimator)
Computes the plan alternatives for this node, an implicitly for all nodes that are children
of this node.
|
DagConnection |
getFirstIncomingConnection()
Gets the DagConnection through which this node receives its first input.
|
OptimizerNode |
getFirstPredecessorNode() |
List<DagConnection> |
getIncomingConnections()
Gets all incoming connections of this node.
|
DualInputOperator<?,?,?,?> |
getOperator()
Gets the operator represented by this optimizer node.
|
protected abstract List<OperatorDescriptorDual> |
getPossibleProperties() |
DagConnection |
getSecondIncomingConnection()
Gets the DagConnection through which this node receives its second input.
|
OptimizerNode |
getSecondPredecessorNode() |
SemanticProperties |
getSemanticProperties() |
protected SemanticProperties |
getSemanticPropertiesForGlobalPropertyFiltering() |
protected SemanticProperties |
getSemanticPropertiesForLocalPropertyFiltering() |
protected void |
instantiate(OperatorDescriptorDual operator,
Channel in1,
Channel in2,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq1,
RequestedGlobalProperties globPropsReq2,
RequestedLocalProperties locPropsReq1,
RequestedLocalProperties locPropsReq2) |
protected void |
placePipelineBreakersIfNecessary(DriverStrategy strategy,
Channel in1,
Channel in2) |
void |
setInput(Map<Operator<?>,OptimizerNode> contractToNode,
ExecutionMode defaultExecutionMode)
This function connects the predecessors to this operator.
|
addBroadcastConnection, addClosedBranch, addClosedBranches, addOutgoingConnection, areBranchCompatible, clearInterestingProperties, computeOperatorSpecificDefaultEstimates, computeOutputEstimates, computeUnclosedBranchStackForBroadcastInputs, computeUnionOfInterestingPropertiesFromSuccessors, getBranchesForParent, getBroadcastConnectionNames, getBroadcastConnections, getClosedBranchingNodes, getCostWeight, getDumpableInputs, getEstimatedAvgWidthPerOutputRecord, getEstimatedNumRecords, getEstimatedOutputSize, getId, getInterestingProperties, getMaxDepth, getMinimalMemoryAcrossAllSubTasks, getOpenBranches, getOperatorName, getOptimizerNode, getOutgoingConnections, getParallelism, getPlanNode, getPredecessors, getUniqueFields, hasUnclosedBranches, haveAllOutputConnectionInterestingProperties, identifyDynamicPath, initId, isBranching, isOnDynamicPath, markAllOutgoingConnectionsAsPipelineBreaking, mergeLists, prunePlanAlternatives, prunePlanAlternativesWithCommonBranching, readStubAnnotations, readUniqueFieldsAnnotation, removeClosedBranches, setBroadcastInputs, setEstimatedNumRecords, setEstimatedOutputSize, setParallelism, toString
protected final FieldList keys1
protected final FieldList keys2
protected DagConnection input1
protected DagConnection input2
public TwoInputNode(DualInputOperator<?,?,?,?> operator)
operator
- The operator that the optimizer DAG node should represent.public DualInputOperator<?,?,?,?> getOperator()
OptimizerNode
getOperator
in class OptimizerNode
public DagConnection getFirstIncomingConnection()
public DagConnection getSecondIncomingConnection()
public OptimizerNode getFirstPredecessorNode()
public OptimizerNode getSecondPredecessorNode()
public List<DagConnection> getIncomingConnections()
OptimizerNode
getIncomingConnections
in class OptimizerNode
public void setInput(Map<Operator<?>,OptimizerNode> contractToNode, ExecutionMode defaultExecutionMode)
OptimizerNode
setInput
in class OptimizerNode
contractToNode
- The map from program operators to optimizer nodes.defaultExecutionMode
- The data exchange mode to use, if the operator does not specify
one.protected abstract List<OperatorDescriptorDual> getPossibleProperties()
public void computeInterestingPropertiesForInputs(CostEstimator estimator)
OptimizerNode
computeInterestingPropertiesForInputs
in class OptimizerNode
estimator
- The CostEstimator
instance to use for plan cost estimation.public List<PlanNode> getAlternativePlans(CostEstimator estimator)
OptimizerNode
getAlternatives()
on its
children to get their plan alternatives, and build its own alternatives on top of those.getAlternativePlans
in class OptimizerNode
estimator
- The cost estimator used to estimate the costs of each plan alternative.protected void addLocalCandidates(Channel template1, Channel template2, List<Set<? extends NamedChannel>> broadcastPlanChannels, RequestedGlobalProperties rgps1, RequestedGlobalProperties rgps2, List<PlanNode> target, OperatorDescriptorDual.LocalPropertiesPair[] validLocalCombinations, CostEstimator estimator)
protected void instantiate(OperatorDescriptorDual operator, Channel in1, Channel in2, List<Set<? extends NamedChannel>> broadcastPlanChannels, List<PlanNode> target, CostEstimator estimator, RequestedGlobalProperties globPropsReq1, RequestedGlobalProperties globPropsReq2, RequestedLocalProperties locPropsReq1, RequestedLocalProperties locPropsReq2)
protected void placePipelineBreakersIfNecessary(DriverStrategy strategy, Channel in1, Channel in2)
public void computeUnclosedBranchStack()
OptimizerNode
openBranches
field to a stack of unclosed branches, the latest one top. A branch is considered closed, if
some later node sees all of the branching node's outputs, no matter if there have been more
branches to different paths in the meantime.computeUnclosedBranchStack
in class OptimizerNode
public SemanticProperties getSemanticProperties()
getSemanticProperties
in class OptimizerNode
protected SemanticProperties getSemanticPropertiesForLocalPropertyFiltering()
protected SemanticProperties getSemanticPropertiesForGlobalPropertyFiltering()
public void accept(Visitor<OptimizerNode> visitor)
OptimizerNode
preVisit()
method, then hand the visitor to their children, and
finally call the postVisit()
method.accept
in interface Visitable<OptimizerNode>
accept
in class OptimizerNode
visitor
- The graph traversing visitor.Visitable.accept(org.apache.flink.util.Visitor)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.