@Internal @Deprecated public class InternalDataStreamQueryOperation<E> extends Object implements QueryOperation
DataStream
.
This is only used for testing.
This operation may expose only part, or change the order of the fields available in a CompositeType
of the underlying DataStream
. The
getFieldIndices()
describes the mapping between fields
of the TableSchema
to the CompositeType
.
Constructor and Description |
---|
InternalDataStreamQueryOperation(ObjectIdentifier identifier,
DataStream<E> dataStream,
int[] fieldIndices,
ResolvedSchema resolvedSchema,
boolean[] fieldNullables,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
<T> T |
accept(QueryOperationVisitor<T> visitor)
Deprecated.
|
String |
asSummaryString()
Deprecated.
Returns a string that summarizes this operation for printing to a console.
|
List<QueryOperation> |
getChildren()
Deprecated.
|
DataStream<E> |
getDataStream()
Deprecated.
|
int[] |
getFieldIndices()
Deprecated.
|
boolean[] |
getFieldNullables()
Deprecated.
|
ObjectIdentifier |
getIdentifier()
Deprecated.
|
ResolvedSchema |
getResolvedSchema()
Deprecated.
Resolved schema of this operation.
|
org.apache.flink.table.planner.plan.stats.FlinkStatistic |
getStatistic()
Deprecated.
|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
asSerializableString
public InternalDataStreamQueryOperation(ObjectIdentifier identifier, DataStream<E> dataStream, int[] fieldIndices, ResolvedSchema resolvedSchema, boolean[] fieldNullables, org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic)
public DataStream<E> getDataStream()
public int[] getFieldIndices()
public ResolvedSchema getResolvedSchema()
QueryOperation
getResolvedSchema
in interface QueryOperation
public String asSummaryString()
Operation
asSummaryString
in interface Operation
public List<QueryOperation> getChildren()
getChildren
in interface QueryOperation
public <T> T accept(QueryOperationVisitor<T> visitor)
accept
in interface QueryOperation
public ObjectIdentifier getIdentifier()
public boolean[] getFieldNullables()
public org.apache.flink.table.planner.plan.stats.FlinkStatistic getStatistic()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.