Uses of Class
org.apache.flink.table.connector.ChangelogMode
-
-
Uses of ChangelogMode in org.apache.flink.connector.datagen.table
Methods in org.apache.flink.connector.datagen.table that return ChangelogMode Modifier and Type Method Description ChangelogMode
DataGenTableSource. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.connector.file.table
Methods in org.apache.flink.connector.file.table that return ChangelogMode Modifier and Type Method Description ChangelogMode
FileSystemTableSink. getChangelogMode(ChangelogMode requestedMode)
ChangelogMode
FileSystemTableSource. getChangelogMode()
Methods in org.apache.flink.connector.file.table with parameters of type ChangelogMode Modifier and Type Method Description ChangelogMode
FileSystemTableSink. getChangelogMode(ChangelogMode requestedMode)
-
Uses of ChangelogMode in org.apache.flink.connectors.hive
Methods in org.apache.flink.connectors.hive that return ChangelogMode Modifier and Type Method Description ChangelogMode
HiveTableSink. getChangelogMode(ChangelogMode requestedMode)
ChangelogMode
HiveTableSource. getChangelogMode()
Methods in org.apache.flink.connectors.hive with parameters of type ChangelogMode Modifier and Type Method Description ChangelogMode
HiveTableSink. getChangelogMode(ChangelogMode requestedMode)
-
Uses of ChangelogMode in org.apache.flink.formats.csv
Methods in org.apache.flink.formats.csv that return ChangelogMode Modifier and Type Method Description ChangelogMode
CsvFileFormatFactory.CsvBulkDecodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.formats.json.canal
Methods in org.apache.flink.formats.json.canal that return ChangelogMode Modifier and Type Method Description ChangelogMode
CanalJsonDecodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.formats.json.debezium
Methods in org.apache.flink.formats.json.debezium that return ChangelogMode Modifier and Type Method Description ChangelogMode
DebeziumJsonDecodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.formats.json.maxwell
Methods in org.apache.flink.formats.json.maxwell that return ChangelogMode Modifier and Type Method Description ChangelogMode
MaxwellJsonDecodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.formats.json.ogg
Methods in org.apache.flink.formats.json.ogg that return ChangelogMode Modifier and Type Method Description ChangelogMode
OggJsonDecodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.formats.parquet
Methods in org.apache.flink.formats.parquet that return ChangelogMode Modifier and Type Method Description ChangelogMode
ParquetFileFormatFactory.ParquetBulkDecodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.formats.protobuf
Methods in org.apache.flink.formats.protobuf that return ChangelogMode Modifier and Type Method Description ChangelogMode
PbDecodingFormat. getChangelogMode()
ChangelogMode
PbEncodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.orc
Methods in org.apache.flink.orc that return ChangelogMode Modifier and Type Method Description ChangelogMode
OrcFileFormatFactory.OrcBulkDecodingFormat. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.table.api.bridge.internal
Methods in org.apache.flink.table.api.bridge.internal with parameters of type ChangelogMode Modifier and Type Method Description protected <T> Table
AbstractStreamTableEnvironmentImpl. fromStreamInternal(DataStream<T> dataStream, Schema schema, String viewPath, ChangelogMode changelogMode)
protected <T> DataStream<T>
AbstractStreamTableEnvironmentImpl. toStreamInternal(Table table, SchemaTranslator.ProducingResult schemaTranslationResult, ChangelogMode changelogMode)
-
Uses of ChangelogMode in org.apache.flink.table.api.bridge.java
Methods in org.apache.flink.table.api.bridge.java with parameters of type ChangelogMode Modifier and Type Method Description Table
StreamTableEnvironment. fromChangelogStream(DataStream<Row> dataStream, Schema schema, ChangelogMode changelogMode)
Converts the givenDataStream
of changelog entries into aTable
.DataStream<Row>
StreamTableEnvironment. toChangelogStream(Table table, Schema targetSchema, ChangelogMode changelogMode)
Converts the givenTable
into aDataStream
of changelog entries. -
Uses of ChangelogMode in org.apache.flink.table.api.bridge.java.internal
Methods in org.apache.flink.table.api.bridge.java.internal with parameters of type ChangelogMode Modifier and Type Method Description Table
StreamTableEnvironmentImpl. fromChangelogStream(DataStream<Row> dataStream, Schema schema, ChangelogMode changelogMode)
DataStream<Row>
StreamTableEnvironmentImpl. toChangelogStream(Table table, Schema targetSchema, ChangelogMode changelogMode)
-
Uses of ChangelogMode in org.apache.flink.table.connector
Methods in org.apache.flink.table.connector that return ChangelogMode Modifier and Type Method Description static ChangelogMode
ChangelogMode. all()
Shortcut for a changelog that can contain allRowKind
s.ChangelogMode
ChangelogMode.Builder. build()
static ChangelogMode
ChangelogMode. insertOnly()
Shortcut for a simpleRowKind.INSERT
-only changelog.static ChangelogMode
ChangelogMode. upsert()
Shortcut for an upsert changelog that describes idempotent updates on a key and thus does not containRowKind.UPDATE_BEFORE
rows. -
Uses of ChangelogMode in org.apache.flink.table.connector.format
Methods in org.apache.flink.table.connector.format that return ChangelogMode Modifier and Type Method Description ChangelogMode
Format. getChangelogMode()
Returns the set of changes that a connector (and transitively the planner) can expect during runtime. -
Uses of ChangelogMode in org.apache.flink.table.connector.sink
Methods in org.apache.flink.table.connector.sink that return ChangelogMode Modifier and Type Method Description ChangelogMode
DynamicTableSink. getChangelogMode(ChangelogMode requestedMode)
Returns the set of changes that the sink accepts during runtime.Methods in org.apache.flink.table.connector.sink with parameters of type ChangelogMode Modifier and Type Method Description ChangelogMode
DynamicTableSink. getChangelogMode(ChangelogMode requestedMode)
Returns the set of changes that the sink accepts during runtime. -
Uses of ChangelogMode in org.apache.flink.table.connector.source
Methods in org.apache.flink.table.connector.source that return ChangelogMode Modifier and Type Method Description ChangelogMode
ScanTableSource. getChangelogMode()
Returns the set of changes that the planner can expect during runtime. -
Uses of ChangelogMode in org.apache.flink.table.examples.java.connectors
Methods in org.apache.flink.table.examples.java.connectors that return ChangelogMode Modifier and Type Method Description ChangelogMode
ChangelogCsvFormat. getChangelogMode()
ChangelogMode
SocketDynamicTableSource. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.table.operations
Methods in org.apache.flink.table.operations that return ChangelogMode Modifier and Type Method Description ChangelogMode
ExternalQueryOperation. getChangelogMode()
Methods in org.apache.flink.table.operations that return types with arguments of type ChangelogMode Modifier and Type Method Description Optional<ChangelogMode>
ExternalModifyOperation. getChangelogMode()
Constructors in org.apache.flink.table.operations with parameters of type ChangelogMode Constructor Description ExternalModifyOperation(ContextResolvedTable contextResolvedTable, QueryOperation child, ChangelogMode changelogMode, DataType physicalDataType)
ExternalQueryOperation(ContextResolvedTable contextResolvedTable, DataStream<E> dataStream, DataType physicalDataType, boolean isTopLevelRecord, ChangelogMode changelogMode)
-
Uses of ChangelogMode in org.apache.flink.table.planner.connectors
Methods in org.apache.flink.table.planner.connectors that return ChangelogMode Modifier and Type Method Description ChangelogMode
CollectDynamicSink. getChangelogMode(ChangelogMode requestedMode)
Methods in org.apache.flink.table.planner.connectors with parameters of type ChangelogMode Modifier and Type Method Description static org.apache.calcite.rel.RelNode
DynamicSourceUtils. convertDataStreamToRel(boolean isBatchMode, ReadableConfig config, FlinkRelBuilder relBuilder, ContextResolvedTable contextResolvedTable, DataStream<?> dataStream, DataType physicalDataType, boolean isTopLevelRecord, ChangelogMode changelogMode)
Converts a givenDataStream
to aRelNode
.ChangelogMode
CollectDynamicSink. getChangelogMode(ChangelogMode requestedMode)
-
Uses of ChangelogMode in org.apache.flink.table.planner.lineage
Methods in org.apache.flink.table.planner.lineage with parameters of type ChangelogMode Modifier and Type Method Description static ModifyType
TableLineageUtils. convert(ChangelogMode inputChangelogMode)
-
Uses of ChangelogMode in org.apache.flink.table.planner.plan.nodes.exec.common
Constructors in org.apache.flink.table.planner.plan.nodes.exec.common with parameters of type ChangelogMode Constructor Description CommonExecLookupJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, LookupJoinUtil.RetryLookupOptions retryOptions, ChangelogMode inputChangelogMode, List<InputProperty> inputProperties, RowType outputType, String description)
CommonExecSink(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, boolean isBounded, List<InputProperty> inputProperties, LogicalType outputType, String description)
-
Uses of ChangelogMode in org.apache.flink.table.planner.plan.nodes.exec.stream
Constructors in org.apache.flink.table.planner.plan.nodes.exec.stream with parameters of type ChangelogMode Constructor Description StreamExecLookupJoin(int id, ExecNodeContext context, ReadableConfig persistedConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, boolean lookupKeyContainsPrimaryKey, boolean upsertMaterialize, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, LookupJoinUtil.RetryLookupOptions retryOptions, ChangelogMode inputChangelogMode, int[] inputUpsertKey, List<StateMetadata> stateMetadataList, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecLookupJoin(ReadableConfig tableConfig, FlinkJoinType joinType, org.apache.calcite.rex.RexNode preFilterCondition, org.apache.calcite.rex.RexNode remainingJoinCondition, TemporalTableSourceSpec temporalTableSourceSpec, Map<Integer,LookupJoinUtil.LookupKey> lookupKeys, List<org.apache.calcite.rex.RexNode> projectionOnTemporalTable, org.apache.calcite.rex.RexNode filterOnTemporalTable, boolean lookupKeyContainsPrimaryKey, boolean upsertMaterialize, LookupJoinUtil.AsyncLookupOptions asyncLookupOptions, LookupJoinUtil.RetryLookupOptions retryOptions, ChangelogMode inputChangelogMode, int[] inputUpsertKey, InputProperty inputProperty, RowType outputType, String description)
StreamExecSink(int id, ExecNodeContext context, ReadableConfig persistedConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, boolean upsertMaterialize, List<StateMetadata> stateMetadataList, int[] inputUpsertKey, List<InputProperty> inputProperties, LogicalType outputType, String description)
StreamExecSink(ReadableConfig tableConfig, DynamicTableSinkSpec tableSinkSpec, ChangelogMode inputChangelogMode, InputProperty inputProperty, LogicalType outputType, boolean upsertMaterialize, int[] inputUpsertKey, String description)
-
Uses of ChangelogMode in org.apache.flink.table.planner.plan.trait
Methods in org.apache.flink.table.planner.plan.trait that return ChangelogMode Modifier and Type Method Description ChangelogMode
ModifyKindSet. toChangelogMode()
Returns the defaultChangelogMode
from thisModifyKindSet
. -
Uses of ChangelogMode in org.apache.flink.table.planner.plan.utils
Methods in org.apache.flink.table.planner.plan.utils with parameters of type ChangelogMode Modifier and Type Method Description static LookupJoinUtil.AsyncLookupOptions
LookupJoinUtil. getMergedAsyncOptions(org.apache.calcite.rel.hint.RelHint lookupHint, TableConfig config, ChangelogMode inputChangelogMode)
-
Uses of ChangelogMode in org.apache.flink.table.toolbox
Methods in org.apache.flink.table.toolbox that return ChangelogMode Modifier and Type Method Description ChangelogMode
TestScanTableSourceWithWatermarkPushDown. getChangelogMode()
-
Uses of ChangelogMode in org.apache.flink.table.utils.python
Methods in org.apache.flink.table.utils.python that return ChangelogMode Modifier and Type Method Description ChangelogMode
PythonDynamicTableSource. getChangelogMode()
-