我用的是flink1.14 
,因为官方没有匹配的版本,所以自己编译的flinkCDC,binlog也开启了,然后也没报错,读不到mysql的数据,idea控制台不报错也不输出数据,可能是什么原因呢(运行日志见附件)
public static void main(String[] args) throws Exception {
Configuration conf = new Configuration();
conf.setInteger("rest.port", 10041);
StreamExecutionEnvironment env = 
StreamExecutionEnvironment.getExecutionEnvironment(conf);
StreamTableEnvironment tenv = StreamTableEnvironment.create(env);

env.enableCheckpointing(1000, CheckpointingMode.EXACTLY_ONCE);
env.getCheckpointConfig().setCheckpointStorage("file:///d:/checkpoint3");

//        StreamTableEnvironment tenv = StreamTableEnvironment.create(env);

env.setParallelism(4);

// 建表
tenv.executeSql("CREATE TABLE flink_t_stu ( " +
"      userid INT, " +
"      username string, " +
"      age string, " +
"      `partition` INT, " +
"     PRIMARY KEY(userid) NOT ENFORCED " +
"     ) WITH ( " +
"     'connector' = 'mysql-cdc', " +
"     'server-id' = '5401-5404', " +
"     'hostname' = '192.168.0.220', " +
"     'port' = '3306', " +
"     'username' = 'root', " +
"     'password' = 'root', " +
"     'database-name' = 'zy', " +
"     'table-name' = 't_stu' " +
")");

// 查询
tenv.executeSql("select * from flink_t_stu").print();

env.execute();

    }
2022-11-03 11:00:07       INFO 
(com.ververica.cdc.connectors.mysql.source.utils.TableDiscoveryUtils:lambda$listTables$1)
 -       including 'zy.t_stu' for further processing
2022-11-03 11:00:07       INFO 
(io.debezium.jdbc.JdbcConnection:lambda$doClose$3) - Connection gracefully 
closed
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.jobmaster.JobMaster:startSchedulingInternal) - 
Starting scheduling with scheduling strategy 
[org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy]
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - Job 
collect (eb0f7496f91a379a11275df436c9126e) switched from state CREATED to 
RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (1/4) (7efdc2342589f6956c0535432b64ff63) 
switched from CREATED to SCHEDULED.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (2/4) (1908624c2dcdcd14e177c97e7cdd2ebd) 
switched from CREATED to SCHEDULED.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (3/4) (3e53cda97f421ec89364880238602f02) 
switched from CREATED to SCHEDULED.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (4/4) (7f41479cd1ae4863689ab9cbea9d78b6) 
switched from CREATED to SCHEDULED.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Sink: Collect table sink (1/1) (4ed520c7f7b76b4206674043f820df1e) switched from 
CREATED to SCHEDULED.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.jobmaster.JobMaster:connectToResourceManager) - 
Connecting to ResourceManager 
akka://flink/user/rpc/resourcemanager_2(a0ede642fd5cff6cbf01b9b62abb4ae7)
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.jobmaster.JobMaster:lambda$startRegistration$0) - 
Resolved ResourceManager address, beginning registration
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.resourcemanager.StandaloneResourceManager:registerJobManager)
 - Registering job manager 
80572ffe1494b6a58e3117fbc66c4d96@akka://flink/user/rpc/jobmanager_3 for job 
eb0f7496f91a379a11275df436c9126e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.resourcemanager.StandaloneResourceManager:registerJobMasterInternal)
 - Registered job manager 
80572ffe1494b6a58e3117fbc66c4d96@akka://flink/user/rpc/jobmanager_3 for job 
eb0f7496f91a379a11275df436c9126e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.jobmaster.JobMaster:establishResourceManagerConnection)
 - JobManager successfully registered at ResourceManager, leader id: 
a0ede642fd5cff6cbf01b9b62abb4ae7.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.resourcemanager.slotmanager.DeclarativeSlotManager:processResourceRequirements)
 - Received resource requirements from job eb0f7496f91a379a11275df436c9126e: 
[ResourceRequirement{resourceProfile=ResourceProfile{UNKNOWN}, 
numberOfRequiredSlots=4}]
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:requestSlot) - Receive slot 
request f15e26f4593fb4df4b06326465c81c3e for job 
eb0f7496f91a379a11275df436c9126e from resource manager with leader id 
a0ede642fd5cff6cbf01b9b62abb4ae7.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:allocateSlot) - Allocated 
slot for f15e26f4593fb4df4b06326465c81c3e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService:addJob) - Add 
job eb0f7496f91a379a11275df436c9126e for job leader monitoring.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService:openRpcConnectionTo)
 - Try to register at job manager akka://flink/user/rpc/jobmanager_3 with 
leader id 8e3117fb-c66c-4d96-8057-2ffe1494b6a5.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:requestSlot) - Receive slot 
request 1cefebb50950fa17158b3f1f599f780c for job 
eb0f7496f91a379a11275df436c9126e from resource manager with leader id 
a0ede642fd5cff6cbf01b9b62abb4ae7.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService:lambda$startRegistration$0)
 - Resolved JobManager address, beginning registration
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:allocateSlot) - Allocated 
slot for 1cefebb50950fa17158b3f1f599f780c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:requestSlot) - Receive slot 
request 34b616a3e5d72b4ef00f142bb404d703 for job 
eb0f7496f91a379a11275df436c9126e from resource manager with leader id 
a0ede642fd5cff6cbf01b9b62abb4ae7.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:allocateSlot) - Allocated 
slot for 34b616a3e5d72b4ef00f142bb404d703.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:requestSlot) - Receive slot 
request 16847e2213cc2fd10aede6e4ac5c899c for job 
eb0f7496f91a379a11275df436c9126e from resource manager with leader id 
a0ede642fd5cff6cbf01b9b62abb4ae7.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:allocateSlot) - Allocated 
slot for 16847e2213cc2fd10aede6e4ac5c899c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.DefaultJobLeaderService:lambda$onRegistrationSuccess$0)
 - Successful registration at job manager akka://flink/user/rpc/jobmanager_3 
for job eb0f7496f91a379a11275df436c9126e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:establishJobManagerConnection)
 - Establish JobManager connection for job eb0f7496f91a379a11275df436c9126e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:internalOfferSlotsToJobManager)
 - Offer reserved slots to the leader of job eb0f7496f91a379a11275df436c9126e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (1/4) (7efdc2342589f6956c0535432b64ff63) 
switched from SCHEDULED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:deploy) - Deploying 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (1/4) (attempt #0) with attempt id 
7efdc2342589f6956c0535432b64ff63 to 877741a6-0f59-4f44-b0bc-d53aafe57af6 @ 
127.0.0.1 (dataPort=-1) with allocation id f15e26f4593fb4df4b06326465c81c3e
2022-11-03 11:00:07       INFO 
(com.ververica.cdc.connectors.mysql.source.assigners.ChunkSplitter:generateSplits)
 - Start splitting table zy.t_stu into chunks...
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (2/4) (1908624c2dcdcd14e177c97e7cdd2ebd) 
switched from SCHEDULED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:deploy) - Deploying 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (2/4) (attempt #0) with attempt id 
1908624c2dcdcd14e177c97e7cdd2ebd to 877741a6-0f59-4f44-b0bc-d53aafe57af6 @ 
127.0.0.1 (dataPort=-1) with allocation id 34b616a3e5d72b4ef00f142bb404d703
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot f15e26f4593fb4df4b06326465c81c3e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (3/4) (3e53cda97f421ec89364880238602f02) 
switched from SCHEDULED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:deploy) - Deploying 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (3/4) (attempt #0) with attempt id 
3e53cda97f421ec89364880238602f02 to 877741a6-0f59-4f44-b0bc-d53aafe57af6 @ 
127.0.0.1 (dataPort=-1) with allocation id 1cefebb50950fa17158b3f1f599f780c
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (4/4) (7f41479cd1ae4863689ab9cbea9d78b6) 
switched from SCHEDULED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:deploy) - Deploying 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (4/4) (attempt #0) with attempt id 
7f41479cd1ae4863689ab9cbea9d78b6 to 877741a6-0f59-4f44-b0bc-d53aafe57af6 @ 
127.0.0.1 (dataPort=-1) with allocation id 16847e2213cc2fd10aede6e4ac5c899c
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Sink: Collect table sink (1/1) (4ed520c7f7b76b4206674043f820df1e) switched from 
SCHEDULED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:deploy) - Deploying 
Sink: Collect table sink (1/1) (attempt #0) with attempt id 
4ed520c7f7b76b4206674043f820df1e to 877741a6-0f59-4f44-b0bc-d53aafe57af6 @ 
127.0.0.1 (dataPort=-1) with allocation id f15e26f4593fb4df4b06326465c81c3e
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.state.changelog.StateChangelogStorageLoader:initialize)
 - StateChangelogStorageLoader initialized with shortcut names {memory}.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.state.changelog.StateChangelogStorageLoader:load) - 
Creating a changelog storage with name 'memory'.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:submitTask) - Received task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (1/4)#0 (7efdc2342589f6956c0535432b64ff63), 
deploy into slot with allocation id f15e26f4593fb4df4b06326465c81c3e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(1/4)#0 (7efdc2342589f6956c0535432b64ff63) switched from CREATED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot 34b616a3e5d72b4ef00f142bb404d703.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:doRun) - Loading JAR files for task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (1/4)#0 (7efdc2342589f6956c0535432b64ff63) 
[DEPLOYING].
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:submitTask) - Received task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (2/4)#0 (1908624c2dcdcd14e177c97e7cdd2ebd), 
deploy into slot with allocation id 34b616a3e5d72b4ef00f142bb404d703.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot 1cefebb50950fa17158b3f1f599f780c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(2/4)#0 (1908624c2dcdcd14e177c97e7cdd2ebd) switched from CREATED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:doRun) - Loading JAR files for task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (2/4)#0 (1908624c2dcdcd14e177c97e7cdd2ebd) 
[DEPLOYING].
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:submitTask) - Received task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (3/4)#0 (3e53cda97f421ec89364880238602f02), 
deploy into slot with allocation id 1cefebb50950fa17158b3f1f599f780c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(3/4)#0 (3e53cda97f421ec89364880238602f02) switched from CREATED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot 16847e2213cc2fd10aede6e4ac5c899c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:doRun) - Loading JAR files for task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (3/4)#0 (3e53cda97f421ec89364880238602f02) 
[DEPLOYING].
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:submitTask) - Received task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (4/4)#0 (7f41479cd1ae4863689ab9cbea9d78b6), 
deploy into slot with allocation id 16847e2213cc2fd10aede6e4ac5c899c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(4/4)#0 (7f41479cd1ae4863689ab9cbea9d78b6) switched from CREATED to DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot f15e26f4593fb4df4b06326465c81c3e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:doRun) - Loading JAR files for task 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (4/4)#0 (7f41479cd1ae4863689ab9cbea9d78b6) 
[DEPLOYING].
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.TaskExecutor:submitTask) - Received task 
Sink: Collect table sink (1/1)#0 (4ed520c7f7b76b4206674043f820df1e), deploy 
into slot with allocation id f15e26f4593fb4df4b06326465c81c3e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Sink: Collect 
table sink (1/1)#0 (4ed520c7f7b76b4206674043f820df1e) switched from CREATED to 
DEPLOYING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:doRun) - Loading JAR files for task 
Sink: Collect table sink (1/1)#0 (4ed520c7f7b76b4206674043f820df1e) [DEPLOYING].
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot 1cefebb50950fa17158b3f1f599f780c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot 16847e2213cc2fd10aede6e4ac5c899c.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot f15e26f4593fb4df4b06326465c81c3e.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl:markExistingSlotActive)
 - Activate slot 34b616a3e5d72b4ef00f142bb404d703.
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:loadFromApplicationOrConfigOrDefaultInternal)
 - No state backend has been configured, using default (HashMap) 
org.apache.flink.runtime.state.hashmap.HashMapStateBackend@2e8902f7
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:loadFromApplicationOrConfigOrDefaultInternal)
 - No state backend has been configured, using default (HashMap) 
org.apache.flink.runtime.state.hashmap.HashMapStateBackend@5539b97d
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:loadFromApplicationOrConfigOrDefaultInternal)
 - No state backend has been configured, using default (HashMap) 
org.apache.flink.runtime.state.hashmap.HashMapStateBackend@4fa5bbbb
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:loadFromApplicationOrConfigOrDefaultInternal)
 - No state backend has been configured, using default (HashMap) 
org.apache.flink.runtime.state.hashmap.HashMapStateBackend@506437f1
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:loadFromApplicationOrConfigOrDefaultInternal)
 - No state backend has been configured, using default (HashMap) 
org.apache.flink.runtime.state.hashmap.HashMapStateBackend@57438d80
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.state.StateBackendLoader:fromApplicationOrConfigOrDefault)
 - State backend loader loads the state backend as HashMapStateBackend
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.state.StateBackendLoader:fromApplicationOrConfigOrDefault)
 - State backend loader loads the state backend as HashMapStateBackend
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.state.StateBackendLoader:fromApplicationOrConfigOrDefault)
 - State backend loader loads the state backend as HashMapStateBackend
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:load) - Using job/cluster 
config to configure application-defined checkpoint storage: 
org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage@5adffa4d
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.state.StateBackendLoader:fromApplicationOrConfigOrDefault)
 - State backend loader loads the state backend as HashMapStateBackend
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:load) - Using job/cluster 
config to configure application-defined checkpoint storage: 
org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage@776fdf11
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:load) - Using job/cluster 
config to configure application-defined checkpoint storage: 
org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage@493f2fae
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:load) - Using job/cluster 
config to configure application-defined checkpoint storage: 
org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage@1b0779b1
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.state.StateBackendLoader:fromApplicationOrConfigOrDefault)
 - State backend loader loads the state backend as HashMapStateBackend
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.runtime.tasks.StreamTask:load) - Using job/cluster 
config to configure application-defined checkpoint storage: 
org.apache.flink.runtime.state.storage.FileSystemCheckpointStorage@7d20f6f7
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(2/4)#0 (1908624c2dcdcd14e177c97e7cdd2ebd) switched from DEPLOYING to 
INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(3/4)#0 (3e53cda97f421ec89364880238602f02) switched from DEPLOYING to 
INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(4/4)#0 (7f41479cd1ae4863689ab9cbea9d78b6) switched from DEPLOYING to 
INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(1/4)#0 (7efdc2342589f6956c0535432b64ff63) switched from DEPLOYING to 
INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Sink: Collect 
table sink (1/1)#0 (4ed520c7f7b76b4206674043f820df1e) switched from DEPLOYING 
to INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (3/4) (3e53cda97f421ec89364880238602f02) 
switched from DEPLOYING to INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (4/4) (7f41479cd1ae4863689ab9cbea9d78b6) 
switched from DEPLOYING to INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (2/4) (1908624c2dcdcd14e177c97e7cdd2ebd) 
switched from DEPLOYING to INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (1/4) (7efdc2342589f6956c0535432b64ff63) 
switched from DEPLOYING to INITIALIZING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Sink: Collect table sink (1/1) (4ed520c7f7b76b4206674043f820df1e) switched from 
DEPLOYING to INITIALIZING.
2022-11-03 11:00:07       WARN 
(org.apache.flink.metrics.MetricGroup:getOrAddOperator) - The operator name 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) exceeded the 80 
characters length limit and was truncated.
2022-11-03 11:00:07       WARN 
(org.apache.flink.metrics.MetricGroup:getOrAddOperator) - The operator name 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) exceeded the 80 
characters length limit and was truncated.
2022-11-03 11:00:07       WARN 
(org.apache.flink.metrics.MetricGroup:getOrAddOperator) - The operator name 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) exceeded the 80 
characters length limit and was truncated.
2022-11-03 11:00:07       WARN 
(org.apache.flink.metrics.MetricGroup:getOrAddOperator) - The operator name 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) exceeded the 80 
characters length limit and was truncated.
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'currentEmitEventTimeLag'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 3]
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'currentEmitEventTimeLag'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 0]
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'currentEmitEventTimeLag'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 1]
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'currentEmitEventTimeLag'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 2]
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'sourceIdleTime'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 3]
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'sourceIdleTime'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 0]
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'sourceIdleTime'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 2]
2022-11-03 11:00:07       WARN (org.apache.flink.metrics.MetricGroup:addMetric) 
- Name collision: Group already contains a Metric with the name 
'sourceIdleTime'. Metric will not be reported.[, taskmanager, 
877741a6-0f59-4f44-b0bc-d53aafe57af6, collect, Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 1]
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.source.coordinator.SourceCoordinator:lambda$handleEventFromOperator$1)
 - Source Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) registering reader 
for parallel task 1 @ 
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.source.coordinator.SourceCoordinator:lambda$handleEventFromOperator$1)
 - Source Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) registering reader 
for parallel task 3 @ 
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.source.coordinator.SourceCoordinator:lambda$handleEventFromOperator$1)
 - Source Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) registering reader 
for parallel task 0 @ 
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.source.coordinator.SourceCoordinator:lambda$handleEventFromOperator$1)
 - Source Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) registering reader 
for parallel task 2 @ 
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.source.coordinator.SourceCoordinator:lambda$handleEventFromOperator$1)
 - Source Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) received split 
request from parallel task 1
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(4/4)#0 (7f41479cd1ae4863689ab9cbea9d78b6) switched from INITIALIZING to 
RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(3/4)#0 (3e53cda97f421ec89364880238602f02) switched from INITIALIZING to 
RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(2/4)#0 (1908624c2dcdcd14e177c97e7cdd2ebd) switched from INITIALIZING to 
RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Source: 
TableSourceScan(table=[[default_catalog, default_database, flink_t_stu]], 
fields=[userid, username, age, partition]) -> NotNullEnforcer(fields=[userid]) 
(1/4)#0 (7efdc2342589f6956c0535432b64ff63) switched from INITIALIZING to 
RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (4/4) (7f41479cd1ae4863689ab9cbea9d78b6) 
switched from INITIALIZING to RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (3/4) (3e53cda97f421ec89364880238602f02) 
switched from INITIALIZING to RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (2/4) (1908624c2dcdcd14e177c97e7cdd2ebd) 
switched from INITIALIZING to RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Source: TableSourceScan(table=[[default_catalog, default_database, 
flink_t_stu]], fields=[userid, username, age, partition]) -> 
NotNullEnforcer(fields=[userid]) (1/4) (7efdc2342589f6956c0535432b64ff63) 
switched from INITIALIZING to RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.api.operators.collect.CollectSinkFunction:initializeState)
 - Initializing collect sink state with offset = 0, buffered results bytes = 0
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.api.operators.collect.CollectSinkFunction:open) - 
Collect sink server established, address = localhost/127.0.0.1:8974
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator:handleEventFromOperator)
 - Received sink socket server address: localhost/127.0.0.1:8974
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.taskmanager.Task:transitionState) - Sink: Collect 
table sink (1/1)#0 (4ed520c7f7b76b4206674043f820df1e) switched from 
INITIALIZING to RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.runtime.executiongraph.ExecutionGraph:transitionState) - 
Sink: Collect table sink (1/1) (4ed520c7f7b76b4206674043f820df1e) switched from 
INITIALIZING to RUNNING.
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.api.operators.collect.CollectSinkOperatorCoordinator:handleRequestImpl)
 - Sink connection established
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.api.operators.collect.CollectSinkFunction:run) - 
Coordinator connection received
2022-11-03 11:00:07       INFO 
(org.apache.flink.streaming.api.operators.collect.CollectSinkFunction:run) - 
Invalid request. Received version = , offset = 0, while expected version = 
29cbbec6-9d48-4b10-8e3b-d7bc3ed65a86, offset = 0
2022-11-03 11:00:08       INFO 
(io.debezium.jdbc.JdbcConnection:lambda$doClose$3) - Connection gracefully 
closed
2022-11-03 11:00:08       INFO 
(org.apache.flink.runtime.checkpoint.CheckpointCoordinator:createPendingCheckpoint)
 - Triggering checkpoint 1 (type=CHECKPOINT) @ 1667444408182 for job 
eb0f7496f91a379a11275df436c9126e.


进程已结束,退出代码为 -1

回复