Package | Description |
---|---|
org.apache.flink.optimizer.dag | |
org.apache.flink.optimizer.dataproperties | |
org.apache.flink.optimizer.operators | |
org.apache.flink.optimizer.plan |
Modifier and Type | Method and Description |
---|---|
protected List<RequestedLocalProperties> |
SortPartitionNode.SortPartitionDescriptor.createPossibleLocalProperties() |
protected List<RequestedLocalProperties> |
PartitionNode.PartitionDescriptor.createPossibleLocalProperties() |
Modifier and Type | Method and Description |
---|---|
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 |
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 |
SingleInputNode.instantiateCandidate(OperatorDescriptorSingle dps,
Channel in,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq,
RequestedLocalProperties locPropsReq) |
protected void |
BulkIterationNode.instantiateCandidate(OperatorDescriptorSingle dps,
Channel in,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq,
RequestedLocalProperties locPropsReq) |
Modifier and Type | Method and Description |
---|---|
RequestedLocalProperties |
RequestedLocalProperties.clone() |
RequestedLocalProperties |
RequestedLocalProperties.filterBySemanticProperties(SemanticProperties props,
int input)
Filters these properties by what can be preserved by the given SemanticProperties when
propagated down to the given input.
|
Modifier and Type | Method and Description |
---|---|
Set<RequestedLocalProperties> |
InterestingProperties.getLocalProperties()
Gets the interesting local properties.
|
Modifier and Type | Method and Description |
---|---|
void |
InterestingProperties.addLocalProperties(RequestedLocalProperties props) |
Modifier and Type | Method and Description |
---|---|
RequestedLocalProperties |
OperatorDescriptorDual.LocalPropertiesPair.getProperties1() |
RequestedLocalProperties |
OperatorDescriptorDual.LocalPropertiesPair.getProperties2() |
Modifier and Type | Method and Description |
---|---|
boolean |
HashFullOuterJoinBuildSecondDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
HashRightOuterJoinBuildSecondDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
HashJoinBuildSecondProperties.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
BinaryUnionOpDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
HashJoinBuildFirstProperties.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
UtilSinkJoinOpDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
CartesianProductDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
HashFullOuterJoinBuildFirstDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
CoGroupDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
HashRightOuterJoinBuildFirstDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
HashLeftOuterJoinBuildFirstDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
AbstractSortMergeJoinDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
HashLeftOuterJoinBuildSecondDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
CoGroupWithSolutionSetSecondDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
abstract boolean |
OperatorDescriptorDual.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
CoGroupRawDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
boolean |
CoGroupWithSolutionSetFirstDescriptor.areCoFulfilled(RequestedLocalProperties requested1,
RequestedLocalProperties requested2,
LocalProperties produced1,
LocalProperties produced2) |
Constructor and Description |
---|
LocalPropertiesPair(RequestedLocalProperties props1,
RequestedLocalProperties props2) |
Modifier and Type | Method and Description |
---|---|
RequestedLocalProperties |
Channel.getRequiredLocalProps() |
Modifier and Type | Method and Description |
---|---|
void |
Channel.setRequiredLocalProps(RequestedLocalProperties requiredLocalProps) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.