Package | Description |
---|---|
org.apache.flink.optimizer.dag | |
org.apache.flink.optimizer.dataproperties | |
org.apache.flink.optimizer.operators | |
org.apache.flink.optimizer.plan | |
org.apache.flink.optimizer.traversals |
This package contains the various traversals over the program plan and the optimizer DAG
(directed acyclic graph) that are made in the course of the optimization.
|
org.apache.flink.optimizer.util |
Modifier and Type | Method and Description |
---|---|
protected void |
TwoInputNode.addLocalCandidates(Channel template1,
Channel template2,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
RequestedGlobalProperties rgps1,
RequestedGlobalProperties rgps2,
List<PlanNode> target,
OperatorDescriptorDual.LocalPropertiesPair[] validLocalCombinations,
CostEstimator estimator) |
protected void |
SingleInputNode.addLocalCandidates(Channel template,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
RequestedGlobalProperties rgps,
List<PlanNode> target,
CostEstimator estimator) |
SingleInputPlanNode |
PartitionNode.PartitionDescriptor.instantiate(Channel in,
SingleInputNode node) |
SingleInputPlanNode |
SortPartitionNode.SortPartitionDescriptor.instantiate(Channel in,
SingleInputNode node) |
protected void |
TwoInputNode.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 |
WorksetIterationNode.instantiate(OperatorDescriptorDual operator,
Channel solutionSetIn,
Channel worksetIn,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReqSolutionSet,
RequestedGlobalProperties globPropsReqWorkset,
RequestedLocalProperties locPropsReqSolutionSet,
RequestedLocalProperties locPropsReqWorkset) |
protected void |
BulkIterationNode.instantiateCandidate(OperatorDescriptorSingle dps,
Channel in,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq,
RequestedLocalProperties locPropsReq) |
protected void |
SingleInputNode.instantiateCandidate(OperatorDescriptorSingle dps,
Channel in,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq,
RequestedLocalProperties locPropsReq) |
protected void |
TwoInputNode.placePipelineBreakersIfNecessary(DriverStrategy strategy,
Channel in1,
Channel in2) |
void |
BulkPartialSolutionNode.setCandidateProperties(GlobalProperties gProps,
LocalProperties lProps,
Channel initialInput) |
void |
WorksetNode.setCandidateProperties(GlobalProperties gProps,
LocalProperties lProps,
Channel initialInput) |
void |
SolutionSetNode.setCandidateProperties(GlobalProperties gProps,
LocalProperties lProps,
Channel initialInput) |
Modifier and Type | Method and Description |
---|---|
void |
RequestedLocalProperties.parameterizeChannel(Channel channel)
Parametrizes the local strategy fields of a channel such that the channel produces the
desired local properties.
|
void |
GlobalProperties.parameterizeChannel(Channel channel,
boolean globalDopChange,
ExecutionMode exchangeMode,
boolean breakPipeline) |
void |
RequestedGlobalProperties.parameterizeChannel(Channel channel,
boolean globalDopChange,
ExecutionMode exchangeMode,
boolean breakPipeline)
Parametrizes the ship strategy fields of a channel such that the channel produces the desired
global properties.
|
Modifier and Type | Class and Description |
---|---|
class |
NamedChannel |
Modifier and Type | Field and Description |
---|---|
protected Channel |
SingleInputPlanNode.input |
protected Channel |
DualInputPlanNode.input1 |
protected Channel |
DualInputPlanNode.input2 |
Modifier and Type | Field and Description |
---|---|
protected List<Channel> |
PlanNode.outChannels |
Modifier and Type | Method and Description |
---|---|
Channel |
Channel.clone() |
Channel |
WorksetIterationPlanNode.getInitialSolutionSetInput() |
Channel |
WorksetIterationPlanNode.getInitialWorksetInput() |
Channel |
SingleInputPlanNode.getInput()
Gets the input channel to this node.
|
Channel |
DualInputPlanNode.getInput1()
Gets the first input channel to this node.
|
Channel |
DualInputPlanNode.getInput2()
Gets the second input channel to this node.
|
Modifier and Type | Method and Description |
---|---|
Iterable<Channel> |
SolutionSetPlanNode.getInputs() |
Iterable<Channel> |
DualInputPlanNode.getInputs() |
Iterable<Channel> |
SourcePlanNode.getInputs() |
Iterable<Channel> |
BulkPartialSolutionPlanNode.getInputs() |
Iterable<Channel> |
NAryUnionPlanNode.getInputs() |
Iterable<Channel> |
SingleInputPlanNode.getInputs() |
Iterable<Channel> |
WorksetPlanNode.getInputs() |
abstract Iterable<Channel> |
PlanNode.getInputs() |
List<Channel> |
NAryUnionPlanNode.getListOfInputs() |
List<Channel> |
PlanNode.getOutgoingChannels()
Gets a list of all outgoing channels leading to successors.
|
Modifier and Type | Method and Description |
---|---|
void |
PlanNode.addOutgoingChannel(Channel channel)
Adds a channel to a successor node to this node.
|
Constructor and Description |
---|
BinaryUnionPlanNode(BinaryUnionNode template,
Channel in1,
Channel in2) |
BulkIterationPlanNode(BulkIterationNode template,
String nodeName,
Channel input,
BulkPartialSolutionPlanNode pspn,
PlanNode rootOfStepFunction) |
BulkIterationPlanNode(BulkIterationNode template,
String nodeName,
Channel input,
BulkPartialSolutionPlanNode pspn,
PlanNode rootOfStepFunction,
PlanNode rootOfTerminationCriterion) |
BulkPartialSolutionPlanNode(BulkPartialSolutionNode template,
String nodeName,
GlobalProperties gProps,
LocalProperties lProps,
Channel initialInput) |
DualInputPlanNode(OptimizerNode template,
String nodeName,
Channel input1,
Channel input2,
DriverStrategy diverStrategy) |
DualInputPlanNode(OptimizerNode template,
String nodeName,
Channel input1,
Channel input2,
DriverStrategy diverStrategy,
FieldList driverKeyFields1,
FieldList driverKeyFields2) |
DualInputPlanNode(OptimizerNode template,
String nodeName,
Channel input1,
Channel input2,
DriverStrategy diverStrategy,
FieldList driverKeyFields1,
FieldList driverKeyFields2,
boolean[] driverSortOrders) |
SingleInputPlanNode(OptimizerNode template,
String nodeName,
Channel input,
DriverStrategy driverStrategy) |
SingleInputPlanNode(OptimizerNode template,
String nodeName,
Channel input,
DriverStrategy driverStrategy,
FieldList driverKeyFields) |
SingleInputPlanNode(OptimizerNode template,
String nodeName,
Channel input,
DriverStrategy driverStrategy,
FieldList driverKeyFields,
boolean[] driverSortOrders) |
SinkJoinerPlanNode(SinkJoiner template,
Channel input1,
Channel input2) |
SinkPlanNode(DataSinkNode template,
String nodeName,
Channel input)
Constructs a new sink candidate node that uses NONE as its local strategy.
|
SolutionSetPlanNode(SolutionSetNode template,
String nodeName,
GlobalProperties gProps,
LocalProperties lProps,
Channel initialInput) |
WorksetIterationPlanNode(WorksetIterationNode template,
String nodeName,
Channel initialSolutionSet,
Channel initialWorkset,
SolutionSetPlanNode solutionSetPlanNode,
WorksetPlanNode worksetPlanNode,
PlanNode nextWorkSetPlanNode,
PlanNode solutionSetDeltaPlanNode) |
WorksetPlanNode(WorksetNode template,
String nodeName,
GlobalProperties gProps,
LocalProperties lProps,
Channel initialInput) |
Constructor and Description |
---|
NAryUnionPlanNode(BinaryUnionNode template,
List<Channel> inputs,
GlobalProperties gProps,
Costs cumulativeCosts) |
Modifier and Type | Method and Description |
---|---|
void |
BinaryUnionReplacer.collect(Channel in,
List<Channel> inputs) |
Modifier and Type | Method and Description |
---|---|
void |
BinaryUnionReplacer.collect(Channel in,
List<Channel> inputs) |
Modifier and Type | Method and Description |
---|---|
static TypeComparatorFactory<?> |
Utils.getShipComparator(Channel channel,
ExecutionConfig executionConfig) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.