public abstract class PostOrderRelNodeVisitor<T> extends Object
Constructor and Description |
---|
PostOrderRelNodeVisitor() |
Modifier and Type | Method and Description |
---|---|
T |
defaultValue(org.apache.calcite.rel.RelNode n,
List<T> inputStreams) |
T |
traverse(org.apache.calcite.rel.RelNode n) |
T |
visitAggregate(org.apache.calcite.rel.core.Aggregate aggregate,
List<T> inputStreams) |
T |
visitCalc(org.apache.calcite.rel.core.Calc calc,
List<T> inputStreams) |
T |
visitCollect(org.apache.calcite.rel.core.Collect collect,
List<T> inputStreams) |
T |
visitCorrelate(org.apache.calcite.rel.core.Correlate correlate,
List<T> inputStreams) |
T |
visitDelta(org.apache.calcite.rel.stream.Delta delta,
List<T> inputStreams) |
T |
visitExchange(org.apache.calcite.rel.core.Exchange exchange,
List<T> inputStreams) |
T |
visitFilter(org.apache.calcite.rel.core.Filter filter,
List<T> inputStreams) |
T |
visitJoin(org.apache.calcite.rel.core.Join join,
List<T> inputStreams) |
T |
visitProject(org.apache.calcite.rel.core.Project project,
List<T> inputStreams) |
T |
visitSample(org.apache.calcite.rel.core.Sample sample,
List<T> inputStreams) |
T |
visitSort(org.apache.calcite.rel.core.Sort sort,
List<T> inputStreams) |
T |
visitTableModify(org.apache.calcite.rel.core.TableModify modify,
List<T> inputStreams) |
T |
visitTableScan(org.apache.calcite.rel.core.TableScan scan,
List<T> inputStreams) |
T |
visitUncollect(org.apache.calcite.rel.core.Uncollect uncollect,
List<T> inputStreams) |
T |
visitWindow(org.apache.calcite.rel.core.Window window,
List<T> inputStreams) |
public final T traverse(org.apache.calcite.rel.RelNode n) throws Exception
Exception
public T visitAggregate(org.apache.calcite.rel.core.Aggregate aggregate, List<T> inputStreams) throws Exception
Exception
public T visitCalc(org.apache.calcite.rel.core.Calc calc, List<T> inputStreams) throws Exception
Exception
public T visitCollect(org.apache.calcite.rel.core.Collect collect, List<T> inputStreams) throws Exception
Exception
public T visitCorrelate(org.apache.calcite.rel.core.Correlate correlate, List<T> inputStreams) throws Exception
Exception
public T visitDelta(org.apache.calcite.rel.stream.Delta delta, List<T> inputStreams) throws Exception
Exception
public T visitExchange(org.apache.calcite.rel.core.Exchange exchange, List<T> inputStreams) throws Exception
Exception
public T visitProject(org.apache.calcite.rel.core.Project project, List<T> inputStreams) throws Exception
Exception
public T visitFilter(org.apache.calcite.rel.core.Filter filter, List<T> inputStreams) throws Exception
Exception
public T visitSample(org.apache.calcite.rel.core.Sample sample, List<T> inputStreams) throws Exception
Exception
public T visitSort(org.apache.calcite.rel.core.Sort sort, List<T> inputStreams) throws Exception
Exception
public T visitTableModify(org.apache.calcite.rel.core.TableModify modify, List<T> inputStreams) throws Exception
Exception
public T visitTableScan(org.apache.calcite.rel.core.TableScan scan, List<T> inputStreams) throws Exception
Exception
public T visitUncollect(org.apache.calcite.rel.core.Uncollect uncollect, List<T> inputStreams) throws Exception
Exception
public T visitWindow(org.apache.calcite.rel.core.Window window, List<T> inputStreams) throws Exception
Exception
public T visitJoin(org.apache.calcite.rel.core.Join join, List<T> inputStreams) throws Exception
Exception
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.