2022-09-19 00:52:01 ERROR i.a.c.l.Exceptions(swallow):66 - Swallowed error. java.lang.NullPointerException: Cannot invoke "io.airbyte.config.Schedule.getTimeUnit()" because "schedule" is null at io.airbyte.config.helpers.ScheduleHelpers.getIntervalInSecond(ScheduleHelpers.java:51) ~[io.airbyte.airbyte-config-config-models-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.TrackingMetadata.generateSyncMetadata(TrackingMetadata.java:41) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.generateSyncMetadata(JobTracker.java:293) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.lambda$trackSync$3(JobTracker.java:138) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.commons.lang.Exceptions.swallow(Exceptions.java:64) ~[io.airbyte-airbyte-commons-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.trackSync(JobTracker.java:123) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.workers.temporal.scheduling.activities.JobCreationAndStatusUpdateActivityImpl.reportJobStart(JobCreationAndStatusUpdateActivityImpl.java:286) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at jdk.internal.reflect.DirectMethodHandleAccessor.invoke(DirectMethodHandleAccessor.java:104) ~[?:?] at java.lang.reflect.Method.invoke(Method.java:578) ~[?:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityInboundCallsInterceptor.execute(POJOActivityTaskHandler.java:214) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityImplementation.execute(POJOActivityTaskHandler.java:180) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler.handle(POJOActivityTaskHandler.java:120) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:204) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:164) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.PollTaskExecutor.lambda$process$0(PollTaskExecutor.java:93) ~[temporal-sdk-1.8.1.jar:?] at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144) [?:?] at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642) [?:?] at java.lang.Thread.run(Thread.java:1589) [?:?] 2022-09-19 00:52:01 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/0/logs.log 2022-09-19 00:52:01 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:01 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/destination-mysql:0.1.20 exists... 2022-09-19 00:52:01 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/destination-mysql:0.1.20 was found locally. 2022-09-19 00:52:01 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = destination-mysql-check-111-0-fxwfd with resources io.airbyte.config.ResourceRequirements@6897296e[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=] 2022-09-19 00:52:01 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/0 --log-driver none --name destination-mysql-check-111-0-fxwfd --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e USE_STREAM_CAPABLE_STATE=true -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e WORKER_CONNECTOR_IMAGE=airbyte/destination-mysql:0.1.20 -e WORKER_JOB_ATTEMPT=0 -e AIRBYTE_VERSION=0.40.4 -e WORKER_JOB_ID=111 airbyte/destination-mysql:0.1.20 check --config source_config.json 2022-09-19 00:52:01 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Class path contains multiple SLF4J bindings. 2022-09-19 00:52:01 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/log4j-slf4j-impl-2.17.1.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:01 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/slf4j-log4j12-1.7.25.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:01 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/logback-classic-1.2.3.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:01 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an explanation. 2022-09-19 00:52:01 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Actual binding is of type [org.apache.logging.slf4j.Log4jLoggerFactory] 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO i.a.i.d.m.MySQLDestination(main):136 - starting destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO i.a.i.b.IntegrationCliParser(parseOptions):118 - integration args: {check=null, config=source_config.json} 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO i.a.i.b.IntegrationRunner(runInternal):123 - Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO i.a.i.b.IntegrationRunner(runInternal):124 - Command: CHECK 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO i.a.i.b.IntegrationRunner(runInternal):125 - Integration config: IntegrationConfig{command=CHECK, configPath='source_config.json', catalogPath='null', statePath='null'} 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword examples - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword multiline - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO i.a.i.b.s.SshTunnel(getInstance):170 - Starting connection with method: NO_TUNNEL 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO c.z.h.HikariDataSource():80 - HikariPool-1 - Starting... 2022-09-19 00:52:02 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:02 INFO c.z.h.HikariDataSource():82 - HikariPool-1 - Start completed. 2022-09-19 00:52:03 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:03 INFO c.z.h.HikariDataSource(close):350 - HikariPool-1 - Shutdown initiated... 2022-09-19 00:52:03 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:03 INFO c.z.h.HikariDataSource(close):352 - HikariPool-1 - Shutdown completed. 2022-09-19 00:52:03 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:03 INFO i.a.i.b.IntegrationRunner(runInternal):171 - Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:03 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:03 INFO i.a.i.d.m.MySQLDestination(main):138 - completed destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:03 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:03 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/0/logs.log 2022-09-19 00:52:03 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:03 INFO i.a.c.EnvConfigs(getEnvOrDefault):1092 - Using default value for environment variable METRIC_CLIENT: '' 2022-09-19 00:52:03 WARN i.a.m.l.MetricClientFactory(initialize):60 - Metric client is already initialized to 2022-09-19 00:52:03 INFO i.a.c.f.EnvVariableFeatureFlags(getEnvOrDefault):49 - Using default value for environment variable LOG_CONNECTOR_MESSAGES: 'false' 2022-09-19 00:52:03 INFO i.a.w.g.DefaultReplicationWorker(run):119 - start sync worker. job id: 111 attempt id: 0 2022-09-19 00:52:03 INFO i.a.w.g.DefaultReplicationWorker(run):131 - configured sync modes: {null.ads_insights=full_refresh - overwrite} 2022-09-19 00:52:03 INFO i.a.w.i.DefaultAirbyteDestination(start):69 - Running destination... 2022-09-19 00:52:03 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/destination-mysql:0.1.20 exists... 2022-09-19 00:52:03 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/destination-mysql:0.1.20 was found locally. 2022-09-19 00:52:03 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = destination-mysql-write-111-0-njmlq with resources null 2022-09-19 00:52:03 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/0 --log-driver none --name destination-mysql-write-111-0-njmlq --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e USE_STREAM_CAPABLE_STATE=true -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e WORKER_CONNECTOR_IMAGE=airbyte/destination-mysql:0.1.20 -e WORKER_JOB_ATTEMPT=0 -e AIRBYTE_VERSION=0.40.4 -e WORKER_JOB_ID=111 airbyte/destination-mysql:0.1.20 write --config destination_config.json --catalog destination_catalog.json 2022-09-19 00:52:03 INFO i.a.w.g.DefaultReplicationWorker(run):173 - Waiting for source and destination threads to complete. 2022-09-19 00:52:03 INFO i.a.w.g.DefaultReplicationWorker(lambda$getDestinationOutputRunnable$7):421 - Destination output thread started. 2022-09-19 00:52:03 INFO i.a.w.g.DefaultReplicationWorker(lambda$getReplicationRunnable$6):313 - Replication thread started. 2022-09-19 00:52:03 INFO i.a.w.g.DefaultReplicationWorker(lambda$getReplicationRunnable$6):350 - Total records read: 1 (0 bytes) 2022-09-19 00:52:03 INFO i.a.w.g.DefaultReplicationWorker(run):178 - One of source or destination thread complete. Waiting on the other. 2022-09-19 00:52:03 destination > SLF4J: Class path contains multiple SLF4J bindings. 2022-09-19 00:52:03 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/log4j-slf4j-impl-2.17.1.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:03 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/slf4j-log4j12-1.7.25.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:03 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/logback-classic-1.2.3.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:03 destination > SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an explanation. 2022-09-19 00:52:03 destination > SLF4J: Actual binding is of type [org.apache.logging.slf4j.Log4jLoggerFactory] 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.d.m.MySQLDestination(main):136 - starting destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.b.IntegrationCliParser(parseOptions):118 - integration args: {catalog=destination_catalog.json, write=null, config=destination_config.json} 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.b.IntegrationRunner(runInternal):123 - Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.b.IntegrationRunner(runInternal):124 - Command: WRITE 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.b.IntegrationRunner(runInternal):125 - Integration config: IntegrationConfig{command=WRITE, configPath='destination_config.json', catalogPath='destination_catalog.json', statePath='null'} 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword examples - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword multiline - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.b.s.SshTunnel(getInstance):170 - Starting connection with method: NO_TUNNEL 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO c.z.h.HikariDataSource():80 - HikariPool-1 - Starting... 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO c.z.h.HikariDataSource():82 - HikariPool-1 - Start completed. 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 - Write config: WriteConfig{streamName=facebookads_insights, namespace=null, outputSchemaName=airbyte, tmpTableName=_airbyte_tmp_lmv_facebookads_insights, outputTableName=_airbyte_raw_facebookads_insights, syncMode=overwrite} 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.d.b.BufferedStreamConsumer(startTracked):116 - class io.airbyte.integrations.destination.buffered_stream_consumer.BufferedStreamConsumer started. 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):123 - Preparing tmp tables in destination started for 1 streams 2022-09-19 00:52:04 destination > 2022-09-19 00:52:04 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):127 - Preparing tmp table in destination started for stream facebookads_insights. schema: airbyte, tmp table name: _airbyte_tmp_lmv_facebookads_insights 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):133 - Preparing tables in destination completed. 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.b.FailureTrackingAirbyteMessageConsumer(close):65 - Airbyte message consumer: succeeded. 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.b.BufferedStreamConsumer(close):171 - executing on success close procedure. 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.SqlOperations(onDestinationCloseOperations):138 - No onDestinationCloseOperations required for this destination. 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):163 - Finalizing tables in destination started for 1 streams 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):168 - Finalizing stream facebookads_insights. schema airbyte, tmp table _airbyte_tmp_lmv_facebookads_insights, final table _airbyte_raw_facebookads_insights 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):181 - Executing finalization of tables. 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):183 - Finalizing tables in destination completed. 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):186 - Cleaning tmp tables in destination started for 1 streams 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):190 - Cleaning tmp table in destination started for stream facebookads_insights. schema airbyte, tmp table name: _airbyte_tmp_lmv_facebookads_insights 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):195 - Cleaning tmp tables in destination completed. 2022-09-19 00:52:05 INFO i.a.w.g.DefaultReplicationWorker(lambda$getDestinationOutputRunnable$7):431 - State in DefaultReplicationWorker from destination: io.airbyte.protocol.models.AirbyteMessage@35466bac[type=STATE,log=,spec=,connectionStatus=,catalog=,record=,state=io.airbyte.protocol.models.AirbyteStateMessage@3b819374[type=LEGACY,stream=,global=,data={},additionalProperties={}],trace=,additionalProperties={}] 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.b.IntegrationRunner(runInternal):171 - Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:05 destination > 2022-09-19 00:52:05 INFO i.a.i.d.m.MySQLDestination(main):138 - completed destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:05 INFO i.a.w.g.DefaultReplicationWorker(run):180 - Source and destination threads complete. 2022-09-19 00:52:05 INFO i.a.w.g.DefaultReplicationWorker(run):249 - sync summary: io.airbyte.config.ReplicationAttemptSummary@5139df7c[status=completed,recordsSynced=0,bytesSynced=0,startTime=1663548723436,endTime=1663548725413,totalStats=io.airbyte.config.SyncStats@7bddbb1e[recordsEmitted=0,bytesEmitted=0,sourceStateMessagesEmitted=1,destinationStateMessagesEmitted=1,recordsCommitted=0,meanSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBetweenStateMessageEmittedandCommitted=2,meanSecondsBetweenStateMessageEmittedandCommitted=2,additionalProperties={}],streamStats=[]] 2022-09-19 00:52:05 INFO i.a.w.g.DefaultReplicationWorker(run):276 - Source output at least one state message 2022-09-19 00:52:05 INFO i.a.w.g.DefaultReplicationWorker(run):282 - State capture: Updated state to: Optional[io.airbyte.config.State@406e2487[state={}]] 2022-09-19 00:52:05 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:05 INFO i.a.w.t.s.ReplicationActivityImpl(lambda$replicate$3):166 - sync summary: io.airbyte.config.StandardSyncOutput@66964a35[standardSyncSummary=io.airbyte.config.StandardSyncSummary@4a84bd5f[status=completed,recordsSynced=0,bytesSynced=0,startTime=1663548723436,endTime=1663548725413,totalStats=io.airbyte.config.SyncStats@7bddbb1e[recordsEmitted=0,bytesEmitted=0,sourceStateMessagesEmitted=1,destinationStateMessagesEmitted=1,recordsCommitted=0,meanSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBetweenStateMessageEmittedandCommitted=2,meanSecondsBetweenStateMessageEmittedandCommitted=2,additionalProperties={}],streamStats=[]],normalizationSummary=,state=io.airbyte.config.State@406e2487[state={}],outputCatalog=io.airbyte.protocol.models.ConfiguredAirbyteCatalog@5c78b751[streams=[io.airbyte.protocol.models.ConfiguredAirbyteStream@19309d2c[stream=io.airbyte.protocol.models.AirbyteStream@4d23abdd[name=facebookads_insights,jsonSchema={"type":["null","object"],"properties":{"cpc":{"type":["null","number"]},"cpm":{"type":["null","number"]},"cpp":{"type":["null","number"]},"ctr":{"type":["null","number"]},"ad_id":{"type":["null","string"]},"reach":{"type":["null","integer"]},"spend":{"type":["null","number"]},"clicks":{"type":["null","integer"]},"labels":{"type":["null","string"]},"actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"ad_name":{"type":["null","string"]},"adset_id":{"type":["null","string"]},"location":{"type":["null","string"]},"wish_bid":{"type":["null","number"]},"date_stop":{"type":["null","string"],"format":"date"},"frequency":{"type":["null","number"]},"objective":{"type":["null","string"]},"account_id":{"type":["null","string"]},"adset_name":{"type":["null","string"]},"date_start":{"type":["null","string"],"format":"date"},"unique_ctr":{"type":["null","number"]},"auction_bid":{"type":["null","number"]},"buying_type":{"type":["null","string"]},"campaign_id":{"type":["null","string"]},"conversions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"impressions":{"type":["null","integer"]},"website_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"account_name":{"type":["null","string"]},"created_time":{"type":["null","string"],"format":"date"},"social_spend":{"type":["null","number"]},"updated_time":{"type":["null","string"],"format":"date"},"action_values":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"age_targeting":{"type":["null","string"]},"campaign_name":{"type":["null","string"]},"purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"unique_clicks":{"type":["null","integer"]},"unique_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"full_view_reach":{"type":["null","number"]},"outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"quality_ranking":{"type":["null","string"]},"account_currency":{"type":["null","string"]},"ad_click_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"gender_targeting":{"type":["null","string"]},"conversion_values":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_ad_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_thruplay":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"optimization_goal":{"type":["null","string"]},"inline_link_clicks":{"type":["null","integer"]},"video_play_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"attribution_setting":{"type":["null","string"]},"cost_per_conversion":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"outbound_clicks_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"canvas_avg_view_time":{"type":["null","number"]},"cost_per_action_type":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"ad_impression_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_click":{"type":["null","number"]},"full_view_impressions":{"type":["null","number"]},"inline_link_click_ctr":{"type":["null","number"]},"website_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"estimated_ad_recallers":{"type":["null","number"]},"inline_post_engagement":{"type":["null","integer"]},"unique_link_clicks_ctr":{"type":["null","number"]},"unique_outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"auction_competitiveness":{"type":["null","number"]},"canvas_avg_view_percent":{"type":["null","number"]},"catalog_segment_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"conversion_rate_ranking":{"type":["null","string"]},"converted_product_value":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_outbound_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"engagement_rate_ranking":{"type":["null","string"]},"estimated_ad_recall_rate":{"type":["null","number"]},"mobile_app_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_curve_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"unique_inline_link_clicks":{"type":["null","integer"]},"video_p25_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p50_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p75_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p95_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"auction_max_competitor_bid":{"type":["null","number"]},"converted_product_quantity":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_15_sec_video_view":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_inline_link_click":{"type":["null","number"]},"unique_outbound_clicks_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p100_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_time_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_action_type":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"unique_inline_link_click_ctr":{"type":["null","number"]},"video_15_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_30_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_outbound_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_avg_time_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_estimated_ad_recallers":{"type":["null","number"]},"cost_per_inline_post_engagement":{"type":["null","number"]},"cost_per_unique_inline_link_click":{"type":["null","number"]},"instant_experience_clicks_to_open":{"type":["null","number"]},"estimated_ad_recallers_lower_bound":{"type":["null","number"]},"estimated_ad_recallers_upper_bound":{"type":["null","number"]},"instant_experience_clicks_to_start":{"type":["null","number"]},"instant_experience_outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_retention_graph_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"cost_per_2_sec_continuous_video_view":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"estimated_ad_recall_rate_lower_bound":{"type":["null","number"]},"estimated_ad_recall_rate_upper_bound":{"type":["null","number"]},"video_play_retention_0_to_15s_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"video_continuous_2_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_retention_20_to_60s_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"qualifying_question_qualify_answer_rate":{"type":["null","number"]},"catalog_segment_value_omni_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value_mobile_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value_website_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}}}},supportedSyncModes=[full_refresh, incremental],sourceDefinedCursor=true,defaultCursorField=[date_start],sourceDefinedPrimaryKey=[[date_start], [account_id], [ad_id]],namespace=,additionalProperties={}],syncMode=full_refresh,cursorField=[date_start],destinationSyncMode=overwrite,primaryKey=[[date_start], [account_id], [ad_id]],additionalProperties={}]],additionalProperties={}],failures=[]] 2022-09-19 00:52:05 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):312 - Stopping temporal heartbeating... 2022-09-19 00:52:05 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/0/logs.log 2022-09-19 00:52:05 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:05 INFO i.a.w.g.DefaultNormalizationWorker(run):57 - Running normalization. 2022-09-19 00:52:05 INFO i.a.w.n.DefaultNormalizationRunner(runProcess):137 - Running with normalization version: airbyte/normalization-mysql:0.2.20 2022-09-19 00:52:05 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/normalization-mysql:0.2.20 exists... 2022-09-19 00:52:05 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/normalization-mysql:0.2.20 was found locally. 2022-09-19 00:52:05 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = normalization-mysql-normalize-111-0-zszrq with resources io.airbyte.config.ResourceRequirements@1dda0cfd[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=] 2022-09-19 00:52:05 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/0/normalize --log-driver none --name normalization-mysql-normalize-111-0-zszrq --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_VERSION=0.40.4 airbyte/normalization-mysql:0.2.20 run --integration-type mysql --config destination_config.json --catalog destination_catalog.json 2022-09-19 00:52:05 INFO i.a.w.g.DefaultNormalizationWorker(run):81 - Normalization executed in 0 seconds. 2022-09-19 00:52:05 normalization > [FATAL tini (6)] exec /airbyte/entrypoint.sh failed: Exec format error 2022-09-19 00:52:05 INFO i.a.w.t.TemporalAttemptExecution(lambda$getWorkerThread$2):162 - Completing future exceptionally... io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:91) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:26) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:159) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at java.lang.Thread.run(Thread.java:1589) [?:?] 2022-09-19 00:52:05 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:05 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):312 - Stopping temporal heartbeating... 2022-09-19 00:52:05 WARN i.t.i.a.POJOActivityTaskHandler(activityFailureToResult):307 - Activity failure. ActivityId=7d278f12-3793-3896-9358-8b4b744fd692, activityType=Normalize, attempt=1 java.lang.RuntimeException: io.temporal.serviceclient.CheckedExceptionWrapper: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:310) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.normalize(NormalizationActivityImpl.java:80) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at jdk.internal.reflect.DirectMethodHandleAccessor.invoke(DirectMethodHandleAccessor.java:104) ~[?:?] at java.lang.reflect.Method.invoke(Method.java:578) ~[?:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityInboundCallsInterceptor.execute(POJOActivityTaskHandler.java:214) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityImplementation.execute(POJOActivityTaskHandler.java:180) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler.handle(POJOActivityTaskHandler.java:120) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:204) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:164) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.PollTaskExecutor.lambda$process$0(PollTaskExecutor.java:93) ~[temporal-sdk-1.8.1.jar:?] at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144) [?:?] at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642) [?:?] at java.lang.Thread.run(Thread.java:1589) [?:?] Caused by: io.temporal.serviceclient.CheckedExceptionWrapper: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.temporal.serviceclient.CheckedExceptionWrapper.wrap(CheckedExceptionWrapper.java:56) ~[temporal-serviceclient-1.8.1.jar:?] at io.temporal.internal.sync.WorkflowInternal.wrap(WorkflowInternal.java:448) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.activity.Activity.wrap(Activity.java:51) ~[temporal-sdk-1.8.1.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.get(TemporalAttemptExecution.java:136) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.lambda$normalize$3(NormalizationActivityImpl.java:108) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:305) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 12 more Caused by: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:396) ~[?:?] at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:2073) ~[?:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.get(TemporalAttemptExecution.java:130) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.lambda$normalize$3(NormalizationActivityImpl.java:108) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:305) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 12 more Caused by: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:91) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:26) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:159) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 1 more 2022-09-19 00:52:06 ERROR i.a.c.l.Exceptions(swallow):66 - Swallowed error. java.lang.NullPointerException: Cannot invoke "io.airbyte.config.Schedule.getTimeUnit()" because "schedule" is null at io.airbyte.config.helpers.ScheduleHelpers.getIntervalInSecond(ScheduleHelpers.java:51) ~[io.airbyte.airbyte-config-config-models-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.TrackingMetadata.generateSyncMetadata(TrackingMetadata.java:41) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.generateSyncMetadata(JobTracker.java:293) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.lambda$trackSync$3(JobTracker.java:138) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.commons.lang.Exceptions.swallow(Exceptions.java:64) ~[io.airbyte-airbyte-commons-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.trackSync(JobTracker.java:123) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.workers.temporal.scheduling.activities.JobCreationAndStatusUpdateActivityImpl.reportJobStart(JobCreationAndStatusUpdateActivityImpl.java:286) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at jdk.internal.reflect.DirectMethodHandleAccessor.invoke(DirectMethodHandleAccessor.java:104) ~[?:?] at java.lang.reflect.Method.invoke(Method.java:578) ~[?:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityInboundCallsInterceptor.execute(POJOActivityTaskHandler.java:214) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityImplementation.execute(POJOActivityTaskHandler.java:180) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler.handle(POJOActivityTaskHandler.java:120) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:204) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:164) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.PollTaskExecutor.lambda$process$0(PollTaskExecutor.java:93) ~[temporal-sdk-1.8.1.jar:?] at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144) [?:?] at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642) [?:?] at java.lang.Thread.run(Thread.java:1589) [?:?] 2022-09-19 00:52:06 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/1/logs.log 2022-09-19 00:52:06 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:06 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/destination-mysql:0.1.20 exists... 2022-09-19 00:52:06 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/destination-mysql:0.1.20 was found locally. 2022-09-19 00:52:06 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = destination-mysql-check-111-1-oabdx with resources io.airbyte.config.ResourceRequirements@6897296e[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=] 2022-09-19 00:52:06 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/1 --log-driver none --name destination-mysql-check-111-1-oabdx --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e USE_STREAM_CAPABLE_STATE=true -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e WORKER_CONNECTOR_IMAGE=airbyte/destination-mysql:0.1.20 -e WORKER_JOB_ATTEMPT=1 -e AIRBYTE_VERSION=0.40.4 -e WORKER_JOB_ID=111 airbyte/destination-mysql:0.1.20 check --config source_config.json 2022-09-19 00:52:06 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Class path contains multiple SLF4J bindings. 2022-09-19 00:52:06 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/log4j-slf4j-impl-2.17.1.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:06 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/slf4j-log4j12-1.7.25.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:06 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/logback-classic-1.2.3.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:06 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an explanation. 2022-09-19 00:52:06 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Actual binding is of type [org.apache.logging.slf4j.Log4jLoggerFactory] 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.d.m.MySQLDestination(main):136 - starting destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.b.IntegrationCliParser(parseOptions):118 - integration args: {check=null, config=source_config.json} 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.b.IntegrationRunner(runInternal):123 - Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.b.IntegrationRunner(runInternal):124 - Command: CHECK 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.b.IntegrationRunner(runInternal):125 - Integration config: IntegrationConfig{command=CHECK, configPath='source_config.json', catalogPath='null', statePath='null'} 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword examples - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword multiline - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.b.s.SshTunnel(getInstance):170 - Starting connection with method: NO_TUNNEL 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO c.z.h.HikariDataSource():80 - HikariPool-1 - Starting... 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO c.z.h.HikariDataSource():82 - HikariPool-1 - Start completed. 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO c.z.h.HikariDataSource(close):350 - HikariPool-1 - Shutdown initiated... 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO c.z.h.HikariDataSource(close):352 - HikariPool-1 - Shutdown completed. 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.b.IntegrationRunner(runInternal):171 - Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:07 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:07 INFO i.a.i.d.m.MySQLDestination(main):138 - completed destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:08 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:08 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/1/logs.log 2022-09-19 00:52:08 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:08 INFO i.a.c.EnvConfigs(getEnvOrDefault):1092 - Using default value for environment variable METRIC_CLIENT: '' 2022-09-19 00:52:08 WARN i.a.m.l.MetricClientFactory(initialize):60 - Metric client is already initialized to 2022-09-19 00:52:08 INFO i.a.c.f.EnvVariableFeatureFlags(getEnvOrDefault):49 - Using default value for environment variable LOG_CONNECTOR_MESSAGES: 'false' 2022-09-19 00:52:08 INFO i.a.w.g.DefaultReplicationWorker(run):119 - start sync worker. job id: 111 attempt id: 1 2022-09-19 00:52:08 INFO i.a.w.g.DefaultReplicationWorker(run):131 - configured sync modes: {null.ads_insights=full_refresh - overwrite} 2022-09-19 00:52:08 INFO i.a.w.i.DefaultAirbyteDestination(start):69 - Running destination... 2022-09-19 00:52:08 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/destination-mysql:0.1.20 exists... 2022-09-19 00:52:08 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/destination-mysql:0.1.20 was found locally. 2022-09-19 00:52:08 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = destination-mysql-write-111-1-kyqmz with resources null 2022-09-19 00:52:08 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/1 --log-driver none --name destination-mysql-write-111-1-kyqmz --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e USE_STREAM_CAPABLE_STATE=true -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e WORKER_CONNECTOR_IMAGE=airbyte/destination-mysql:0.1.20 -e WORKER_JOB_ATTEMPT=1 -e AIRBYTE_VERSION=0.40.4 -e WORKER_JOB_ID=111 airbyte/destination-mysql:0.1.20 write --config destination_config.json --catalog destination_catalog.json 2022-09-19 00:52:08 INFO i.a.w.g.DefaultReplicationWorker(lambda$getDestinationOutputRunnable$7):421 - Destination output thread started. 2022-09-19 00:52:08 INFO i.a.w.g.DefaultReplicationWorker(run):173 - Waiting for source and destination threads to complete. 2022-09-19 00:52:08 INFO i.a.w.g.DefaultReplicationWorker(lambda$getReplicationRunnable$6):313 - Replication thread started. 2022-09-19 00:52:08 INFO i.a.w.g.DefaultReplicationWorker(lambda$getReplicationRunnable$6):350 - Total records read: 1 (0 bytes) 2022-09-19 00:52:08 INFO i.a.w.g.DefaultReplicationWorker(run):178 - One of source or destination thread complete. Waiting on the other. 2022-09-19 00:52:08 destination > SLF4J: Class path contains multiple SLF4J bindings. 2022-09-19 00:52:08 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/log4j-slf4j-impl-2.17.1.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:08 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/slf4j-log4j12-1.7.25.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:08 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/logback-classic-1.2.3.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:08 destination > SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an explanation. 2022-09-19 00:52:08 destination > SLF4J: Actual binding is of type [org.apache.logging.slf4j.Log4jLoggerFactory] 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.d.m.MySQLDestination(main):136 - starting destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.b.IntegrationCliParser(parseOptions):118 - integration args: {catalog=destination_catalog.json, write=null, config=destination_config.json} 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.b.IntegrationRunner(runInternal):123 - Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.b.IntegrationRunner(runInternal):124 - Command: WRITE 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.b.IntegrationRunner(runInternal):125 - Integration config: IntegrationConfig{command=WRITE, configPath='destination_config.json', catalogPath='destination_catalog.json', statePath='null'} 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword examples - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword multiline - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.b.s.SshTunnel(getInstance):170 - Starting connection with method: NO_TUNNEL 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO c.z.h.HikariDataSource():80 - HikariPool-1 - Starting... 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO c.z.h.HikariDataSource():82 - HikariPool-1 - Start completed. 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 - Write config: WriteConfig{streamName=facebookads_insights, namespace=null, outputSchemaName=airbyte, tmpTableName=_airbyte_tmp_muz_facebookads_insights, outputTableName=_airbyte_raw_facebookads_insights, syncMode=overwrite} 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.d.b.BufferedStreamConsumer(startTracked):116 - class io.airbyte.integrations.destination.buffered_stream_consumer.BufferedStreamConsumer started. 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):123 - Preparing tmp tables in destination started for 1 streams 2022-09-19 00:52:09 destination > 2022-09-19 00:52:09 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):127 - Preparing tmp table in destination started for stream facebookads_insights. schema: airbyte, tmp table name: _airbyte_tmp_muz_facebookads_insights 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):133 - Preparing tables in destination completed. 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.b.FailureTrackingAirbyteMessageConsumer(close):65 - Airbyte message consumer: succeeded. 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.b.BufferedStreamConsumer(close):171 - executing on success close procedure. 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.SqlOperations(onDestinationCloseOperations):138 - No onDestinationCloseOperations required for this destination. 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):163 - Finalizing tables in destination started for 1 streams 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):168 - Finalizing stream facebookads_insights. schema airbyte, tmp table _airbyte_tmp_muz_facebookads_insights, final table _airbyte_raw_facebookads_insights 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):181 - Executing finalization of tables. 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):183 - Finalizing tables in destination completed. 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):186 - Cleaning tmp tables in destination started for 1 streams 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):190 - Cleaning tmp table in destination started for stream facebookads_insights. schema airbyte, tmp table name: _airbyte_tmp_muz_facebookads_insights 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):195 - Cleaning tmp tables in destination completed. 2022-09-19 00:52:10 INFO i.a.w.g.DefaultReplicationWorker(lambda$getDestinationOutputRunnable$7):431 - State in DefaultReplicationWorker from destination: io.airbyte.protocol.models.AirbyteMessage@77dbae4[type=STATE,log=,spec=,connectionStatus=,catalog=,record=,state=io.airbyte.protocol.models.AirbyteStateMessage@9ba447b[type=LEGACY,stream=,global=,data={},additionalProperties={}],trace=,additionalProperties={}] 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.b.IntegrationRunner(runInternal):171 - Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:10 destination > 2022-09-19 00:52:10 INFO i.a.i.d.m.MySQLDestination(main):138 - completed destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:10 INFO i.a.w.g.DefaultReplicationWorker(run):180 - Source and destination threads complete. 2022-09-19 00:52:10 INFO i.a.w.g.DefaultReplicationWorker(run):249 - sync summary: io.airbyte.config.ReplicationAttemptSummary@32e2b29[status=completed,recordsSynced=0,bytesSynced=0,startTime=1663548728190,endTime=1663548730161,totalStats=io.airbyte.config.SyncStats@2fe59624[recordsEmitted=0,bytesEmitted=0,sourceStateMessagesEmitted=1,destinationStateMessagesEmitted=1,recordsCommitted=0,meanSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBetweenStateMessageEmittedandCommitted=2,meanSecondsBetweenStateMessageEmittedandCommitted=2,additionalProperties={}],streamStats=[]] 2022-09-19 00:52:10 INFO i.a.w.g.DefaultReplicationWorker(run):276 - Source output at least one state message 2022-09-19 00:52:10 INFO i.a.w.g.DefaultReplicationWorker(run):282 - State capture: Updated state to: Optional[io.airbyte.config.State@1d95cb88[state={}]] 2022-09-19 00:52:10 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:10 INFO i.a.w.t.s.ReplicationActivityImpl(lambda$replicate$3):166 - sync summary: io.airbyte.config.StandardSyncOutput@4f9e2f82[standardSyncSummary=io.airbyte.config.StandardSyncSummary@67f687b9[status=completed,recordsSynced=0,bytesSynced=0,startTime=1663548728190,endTime=1663548730161,totalStats=io.airbyte.config.SyncStats@2fe59624[recordsEmitted=0,bytesEmitted=0,sourceStateMessagesEmitted=1,destinationStateMessagesEmitted=1,recordsCommitted=0,meanSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBetweenStateMessageEmittedandCommitted=2,meanSecondsBetweenStateMessageEmittedandCommitted=2,additionalProperties={}],streamStats=[]],normalizationSummary=,state=io.airbyte.config.State@1d95cb88[state={}],outputCatalog=io.airbyte.protocol.models.ConfiguredAirbyteCatalog@1a241a5d[streams=[io.airbyte.protocol.models.ConfiguredAirbyteStream@fb6b680[stream=io.airbyte.protocol.models.AirbyteStream@316a7acb[name=facebookads_insights,jsonSchema={"type":["null","object"],"properties":{"cpc":{"type":["null","number"]},"cpm":{"type":["null","number"]},"cpp":{"type":["null","number"]},"ctr":{"type":["null","number"]},"ad_id":{"type":["null","string"]},"reach":{"type":["null","integer"]},"spend":{"type":["null","number"]},"clicks":{"type":["null","integer"]},"labels":{"type":["null","string"]},"actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"ad_name":{"type":["null","string"]},"adset_id":{"type":["null","string"]},"location":{"type":["null","string"]},"wish_bid":{"type":["null","number"]},"date_stop":{"type":["null","string"],"format":"date"},"frequency":{"type":["null","number"]},"objective":{"type":["null","string"]},"account_id":{"type":["null","string"]},"adset_name":{"type":["null","string"]},"date_start":{"type":["null","string"],"format":"date"},"unique_ctr":{"type":["null","number"]},"auction_bid":{"type":["null","number"]},"buying_type":{"type":["null","string"]},"campaign_id":{"type":["null","string"]},"conversions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"impressions":{"type":["null","integer"]},"website_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"account_name":{"type":["null","string"]},"created_time":{"type":["null","string"],"format":"date"},"social_spend":{"type":["null","number"]},"updated_time":{"type":["null","string"],"format":"date"},"action_values":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"age_targeting":{"type":["null","string"]},"campaign_name":{"type":["null","string"]},"purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"unique_clicks":{"type":["null","integer"]},"unique_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"full_view_reach":{"type":["null","number"]},"outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"quality_ranking":{"type":["null","string"]},"account_currency":{"type":["null","string"]},"ad_click_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"gender_targeting":{"type":["null","string"]},"conversion_values":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_ad_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_thruplay":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"optimization_goal":{"type":["null","string"]},"inline_link_clicks":{"type":["null","integer"]},"video_play_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"attribution_setting":{"type":["null","string"]},"cost_per_conversion":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"outbound_clicks_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"canvas_avg_view_time":{"type":["null","number"]},"cost_per_action_type":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"ad_impression_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_click":{"type":["null","number"]},"full_view_impressions":{"type":["null","number"]},"inline_link_click_ctr":{"type":["null","number"]},"website_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"estimated_ad_recallers":{"type":["null","number"]},"inline_post_engagement":{"type":["null","integer"]},"unique_link_clicks_ctr":{"type":["null","number"]},"unique_outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"auction_competitiveness":{"type":["null","number"]},"canvas_avg_view_percent":{"type":["null","number"]},"catalog_segment_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"conversion_rate_ranking":{"type":["null","string"]},"converted_product_value":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_outbound_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"engagement_rate_ranking":{"type":["null","string"]},"estimated_ad_recall_rate":{"type":["null","number"]},"mobile_app_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_curve_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"unique_inline_link_clicks":{"type":["null","integer"]},"video_p25_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p50_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p75_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p95_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"auction_max_competitor_bid":{"type":["null","number"]},"converted_product_quantity":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_15_sec_video_view":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_inline_link_click":{"type":["null","number"]},"unique_outbound_clicks_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p100_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_time_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_action_type":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"unique_inline_link_click_ctr":{"type":["null","number"]},"video_15_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_30_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_outbound_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_avg_time_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_estimated_ad_recallers":{"type":["null","number"]},"cost_per_inline_post_engagement":{"type":["null","number"]},"cost_per_unique_inline_link_click":{"type":["null","number"]},"instant_experience_clicks_to_open":{"type":["null","number"]},"estimated_ad_recallers_lower_bound":{"type":["null","number"]},"estimated_ad_recallers_upper_bound":{"type":["null","number"]},"instant_experience_clicks_to_start":{"type":["null","number"]},"instant_experience_outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_retention_graph_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"cost_per_2_sec_continuous_video_view":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"estimated_ad_recall_rate_lower_bound":{"type":["null","number"]},"estimated_ad_recall_rate_upper_bound":{"type":["null","number"]},"video_play_retention_0_to_15s_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"video_continuous_2_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_retention_20_to_60s_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"qualifying_question_qualify_answer_rate":{"type":["null","number"]},"catalog_segment_value_omni_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value_mobile_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value_website_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}}}},supportedSyncModes=[full_refresh, incremental],sourceDefinedCursor=true,defaultCursorField=[date_start],sourceDefinedPrimaryKey=[[date_start], [account_id], [ad_id]],namespace=,additionalProperties={}],syncMode=full_refresh,cursorField=[date_start],destinationSyncMode=overwrite,primaryKey=[[date_start], [account_id], [ad_id]],additionalProperties={}]],additionalProperties={}],failures=[]] 2022-09-19 00:52:10 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):312 - Stopping temporal heartbeating... 2022-09-19 00:52:10 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/1/logs.log 2022-09-19 00:52:10 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:10 INFO i.a.w.g.DefaultNormalizationWorker(run):57 - Running normalization. 2022-09-19 00:52:10 INFO i.a.w.n.DefaultNormalizationRunner(runProcess):137 - Running with normalization version: airbyte/normalization-mysql:0.2.20 2022-09-19 00:52:10 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/normalization-mysql:0.2.20 exists... 2022-09-19 00:52:10 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/normalization-mysql:0.2.20 was found locally. 2022-09-19 00:52:10 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = normalization-mysql-normalize-111-1-cbuqj with resources io.airbyte.config.ResourceRequirements@85fb81f[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=] 2022-09-19 00:52:10 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/1/normalize --log-driver none --name normalization-mysql-normalize-111-1-cbuqj --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_VERSION=0.40.4 airbyte/normalization-mysql:0.2.20 run --integration-type mysql --config destination_config.json --catalog destination_catalog.json 2022-09-19 00:52:10 normalization > [FATAL tini (7)] exec /airbyte/entrypoint.sh failed: Exec format error 2022-09-19 00:52:10 INFO i.a.w.g.DefaultNormalizationWorker(run):81 - Normalization executed in 0 seconds. 2022-09-19 00:52:10 INFO i.a.w.t.TemporalAttemptExecution(lambda$getWorkerThread$2):162 - Completing future exceptionally... io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:91) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:26) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:159) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at java.lang.Thread.run(Thread.java:1589) [?:?] 2022-09-19 00:52:10 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:10 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):312 - Stopping temporal heartbeating... 2022-09-19 00:52:10 WARN i.t.i.a.POJOActivityTaskHandler(activityFailureToResult):307 - Activity failure. ActivityId=cee826b8-b11f-38f2-8bc9-04163ca1fb64, activityType=Normalize, attempt=1 java.lang.RuntimeException: io.temporal.serviceclient.CheckedExceptionWrapper: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:310) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.normalize(NormalizationActivityImpl.java:80) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at jdk.internal.reflect.DirectMethodHandleAccessor.invoke(DirectMethodHandleAccessor.java:104) ~[?:?] at java.lang.reflect.Method.invoke(Method.java:578) ~[?:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityInboundCallsInterceptor.execute(POJOActivityTaskHandler.java:214) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityImplementation.execute(POJOActivityTaskHandler.java:180) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler.handle(POJOActivityTaskHandler.java:120) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:204) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:164) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.PollTaskExecutor.lambda$process$0(PollTaskExecutor.java:93) ~[temporal-sdk-1.8.1.jar:?] at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144) [?:?] at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642) [?:?] at java.lang.Thread.run(Thread.java:1589) [?:?] Caused by: io.temporal.serviceclient.CheckedExceptionWrapper: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.temporal.serviceclient.CheckedExceptionWrapper.wrap(CheckedExceptionWrapper.java:56) ~[temporal-serviceclient-1.8.1.jar:?] at io.temporal.internal.sync.WorkflowInternal.wrap(WorkflowInternal.java:448) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.activity.Activity.wrap(Activity.java:51) ~[temporal-sdk-1.8.1.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.get(TemporalAttemptExecution.java:136) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.lambda$normalize$3(NormalizationActivityImpl.java:108) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:305) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 12 more Caused by: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:396) ~[?:?] at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:2073) ~[?:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.get(TemporalAttemptExecution.java:130) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.lambda$normalize$3(NormalizationActivityImpl.java:108) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:305) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 12 more Caused by: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:91) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:26) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:159) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 1 more 2022-09-19 00:52:10 ERROR i.a.c.l.Exceptions(swallow):66 - Swallowed error. java.lang.NullPointerException: Cannot invoke "io.airbyte.config.Schedule.getTimeUnit()" because "schedule" is null at io.airbyte.config.helpers.ScheduleHelpers.getIntervalInSecond(ScheduleHelpers.java:51) ~[io.airbyte.airbyte-config-config-models-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.TrackingMetadata.generateSyncMetadata(TrackingMetadata.java:41) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.generateSyncMetadata(JobTracker.java:293) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.lambda$trackSync$3(JobTracker.java:138) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.commons.lang.Exceptions.swallow(Exceptions.java:64) ~[io.airbyte-airbyte-commons-0.40.4.jar:?] at io.airbyte.scheduler.persistence.job_tracker.JobTracker.trackSync(JobTracker.java:123) ~[io.airbyte.airbyte-scheduler-scheduler-persistence-0.40.4.jar:?] at io.airbyte.workers.temporal.scheduling.activities.JobCreationAndStatusUpdateActivityImpl.reportJobStart(JobCreationAndStatusUpdateActivityImpl.java:286) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at jdk.internal.reflect.DirectMethodHandleAccessor.invoke(DirectMethodHandleAccessor.java:104) ~[?:?] at java.lang.reflect.Method.invoke(Method.java:578) ~[?:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityInboundCallsInterceptor.execute(POJOActivityTaskHandler.java:214) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityImplementation.execute(POJOActivityTaskHandler.java:180) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler.handle(POJOActivityTaskHandler.java:120) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:204) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:164) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.PollTaskExecutor.lambda$process$0(PollTaskExecutor.java:93) ~[temporal-sdk-1.8.1.jar:?] at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144) [?:?] at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642) [?:?] at java.lang.Thread.run(Thread.java:1589) [?:?] 2022-09-19 00:52:10 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/2/logs.log 2022-09-19 00:52:10 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:10 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/destination-mysql:0.1.20 exists... 2022-09-19 00:52:10 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/destination-mysql:0.1.20 was found locally. 2022-09-19 00:52:10 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = destination-mysql-check-111-2-ggjhf with resources io.airbyte.config.ResourceRequirements@6897296e[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=] 2022-09-19 00:52:10 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/2 --log-driver none --name destination-mysql-check-111-2-ggjhf --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e USE_STREAM_CAPABLE_STATE=true -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e WORKER_CONNECTOR_IMAGE=airbyte/destination-mysql:0.1.20 -e WORKER_JOB_ATTEMPT=2 -e AIRBYTE_VERSION=0.40.4 -e WORKER_JOB_ID=111 airbyte/destination-mysql:0.1.20 check --config source_config.json 2022-09-19 00:52:11 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Class path contains multiple SLF4J bindings. 2022-09-19 00:52:11 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/log4j-slf4j-impl-2.17.1.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:11 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/slf4j-log4j12-1.7.25.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:11 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Found binding in [jar:file:/airbyte/lib/logback-classic-1.2.3.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:11 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an explanation. 2022-09-19 00:52:11 ERROR i.a.c.i.LineGobbler(voidCall):83 - SLF4J: Actual binding is of type [org.apache.logging.slf4j.Log4jLoggerFactory] 2022-09-19 00:52:11 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:11 INFO i.a.i.d.m.MySQLDestination(main):136 - starting destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:11 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:11 INFO i.a.i.b.IntegrationCliParser(parseOptions):118 - integration args: {check=null, config=source_config.json} 2022-09-19 00:52:11 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:11 INFO i.a.i.b.IntegrationRunner(runInternal):123 - Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:11 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:11 INFO i.a.i.b.IntegrationRunner(runInternal):124 - Command: CHECK 2022-09-19 00:52:11 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:11 INFO i.a.i.b.IntegrationRunner(runInternal):125 - Integration config: IntegrationConfig{command=CHECK, configPath='source_config.json', catalogPath='null', statePath='null'} 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword examples - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword multiline - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 INFO i.a.i.b.s.SshTunnel(getInstance):170 - Starting connection with method: NO_TUNNEL 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 INFO c.z.h.HikariDataSource():80 - HikariPool-1 - Starting... 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 INFO c.z.h.HikariDataSource():82 - HikariPool-1 - Start completed. 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 INFO c.z.h.HikariDataSource(close):350 - HikariPool-1 - Shutdown initiated... 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 INFO c.z.h.HikariDataSource(close):352 - HikariPool-1 - Shutdown completed. 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 INFO i.a.i.b.IntegrationRunner(runInternal):171 - Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteStreamFactory(lambda$create$0):61 - 2022-09-19 00:52:12 INFO i.a.i.d.m.MySQLDestination(main):138 - completed destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:12 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:12 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/2/logs.log 2022-09-19 00:52:12 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:12 INFO i.a.c.EnvConfigs(getEnvOrDefault):1092 - Using default value for environment variable METRIC_CLIENT: '' 2022-09-19 00:52:12 WARN i.a.m.l.MetricClientFactory(initialize):60 - Metric client is already initialized to 2022-09-19 00:52:12 INFO i.a.c.f.EnvVariableFeatureFlags(getEnvOrDefault):49 - Using default value for environment variable LOG_CONNECTOR_MESSAGES: 'false' 2022-09-19 00:52:12 INFO i.a.w.g.DefaultReplicationWorker(run):119 - start sync worker. job id: 111 attempt id: 2 2022-09-19 00:52:12 INFO i.a.w.g.DefaultReplicationWorker(run):131 - configured sync modes: {null.ads_insights=full_refresh - overwrite} 2022-09-19 00:52:12 INFO i.a.w.i.DefaultAirbyteDestination(start):69 - Running destination... 2022-09-19 00:52:12 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/destination-mysql:0.1.20 exists... 2022-09-19 00:52:12 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/destination-mysql:0.1.20 was found locally. 2022-09-19 00:52:12 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = destination-mysql-write-111-2-gxgxo with resources null 2022-09-19 00:52:12 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/2 --log-driver none --name destination-mysql-write-111-2-gxgxo --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e USE_STREAM_CAPABLE_STATE=true -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e WORKER_CONNECTOR_IMAGE=airbyte/destination-mysql:0.1.20 -e WORKER_JOB_ATTEMPT=2 -e AIRBYTE_VERSION=0.40.4 -e WORKER_JOB_ID=111 airbyte/destination-mysql:0.1.20 write --config destination_config.json --catalog destination_catalog.json 2022-09-19 00:52:12 INFO i.a.w.g.DefaultReplicationWorker(lambda$getDestinationOutputRunnable$7):421 - Destination output thread started. 2022-09-19 00:52:12 INFO i.a.w.g.DefaultReplicationWorker(run):173 - Waiting for source and destination threads to complete. 2022-09-19 00:52:12 INFO i.a.w.g.DefaultReplicationWorker(lambda$getReplicationRunnable$6):313 - Replication thread started. 2022-09-19 00:52:12 INFO i.a.w.g.DefaultReplicationWorker(lambda$getReplicationRunnable$6):350 - Total records read: 1 (0 bytes) 2022-09-19 00:52:12 INFO i.a.w.g.DefaultReplicationWorker(run):178 - One of source or destination thread complete. Waiting on the other. 2022-09-19 00:52:13 destination > SLF4J: Class path contains multiple SLF4J bindings. 2022-09-19 00:52:13 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/log4j-slf4j-impl-2.17.1.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:13 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/slf4j-log4j12-1.7.25.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:13 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/logback-classic-1.2.3.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-09-19 00:52:13 destination > SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an explanation. 2022-09-19 00:52:13 destination > SLF4J: Actual binding is of type [org.apache.logging.slf4j.Log4jLoggerFactory] 2022-09-19 00:52:13 destination > 2022-09-19 00:52:13 INFO i.a.i.d.m.MySQLDestination(main):136 - starting destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:13 destination > 2022-09-19 00:52:13 INFO i.a.i.b.IntegrationCliParser(parseOptions):118 - integration args: {catalog=destination_catalog.json, write=null, config=destination_config.json} 2022-09-19 00:52:13 destination > 2022-09-19 00:52:13 INFO i.a.i.b.IntegrationRunner(runInternal):123 - Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:13 destination > 2022-09-19 00:52:13 INFO i.a.i.b.IntegrationRunner(runInternal):124 - Command: WRITE 2022-09-19 00:52:13 destination > 2022-09-19 00:52:13 INFO i.a.i.b.IntegrationRunner(runInternal):125 - Integration config: IntegrationConfig{command=WRITE, configPath='destination_config.json', catalogPath='destination_catalog.json', statePath='null'} 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword examples - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword multiline - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.b.s.SshTunnel(getInstance):170 - Starting connection with method: NO_TUNNEL 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO c.z.h.HikariDataSource():80 - HikariPool-1 - Starting... 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO c.z.h.HikariDataSource():82 - HikariPool-1 - Start completed. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 - Write config: WriteConfig{streamName=facebookads_insights, namespace=null, outputSchemaName=airbyte, tmpTableName=_airbyte_tmp_qpm_facebookads_insights, outputTableName=_airbyte_raw_facebookads_insights, syncMode=overwrite} 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.b.BufferedStreamConsumer(startTracked):116 - class io.airbyte.integrations.destination.buffered_stream_consumer.BufferedStreamConsumer started. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):123 - Preparing tmp tables in destination started for 1 streams 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):127 - Preparing tmp table in destination started for stream facebookads_insights. schema: airbyte, tmp table name: _airbyte_tmp_qpm_facebookads_insights 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):133 - Preparing tables in destination completed. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.b.FailureTrackingAirbyteMessageConsumer(close):65 - Airbyte message consumer: succeeded. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.b.BufferedStreamConsumer(close):171 - executing on success close procedure. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.SqlOperations(onDestinationCloseOperations):138 - No onDestinationCloseOperations required for this destination. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):163 - Finalizing tables in destination started for 1 streams 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):168 - Finalizing stream facebookads_insights. schema airbyte, tmp table _airbyte_tmp_qpm_facebookads_insights, final table _airbyte_raw_facebookads_insights 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):181 - Executing finalization of tables. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):183 - Finalizing tables in destination completed. 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):186 - Cleaning tmp tables in destination started for 1 streams 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):190 - Cleaning tmp table in destination started for stream facebookads_insights. schema airbyte, tmp table name: _airbyte_tmp_qpm_facebookads_insights 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onCloseFunction$3):195 - Cleaning tmp tables in destination completed. 2022-09-19 00:52:14 INFO i.a.w.g.DefaultReplicationWorker(lambda$getDestinationOutputRunnable$7):431 - State in DefaultReplicationWorker from destination: io.airbyte.protocol.models.AirbyteMessage@6d15818e[type=STATE,log=,spec=,connectionStatus=,catalog=,record=,state=io.airbyte.protocol.models.AirbyteStateMessage@63d2725c[type=LEGACY,stream=,global=,data={},additionalProperties={}],trace=,additionalProperties={}] 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.b.IntegrationRunner(runInternal):171 - Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination 2022-09-19 00:52:14 destination > 2022-09-19 00:52:14 INFO i.a.i.d.m.MySQLDestination(main):138 - completed destination: class io.airbyte.integrations.destination.mysql.MySQLDestination 2022-09-19 00:52:14 INFO i.a.w.g.DefaultReplicationWorker(run):180 - Source and destination threads complete. 2022-09-19 00:52:14 INFO i.a.w.g.DefaultReplicationWorker(run):249 - sync summary: io.airbyte.config.ReplicationAttemptSummary@3d46ff8a[status=completed,recordsSynced=0,bytesSynced=0,startTime=1663548732945,endTime=1663548734958,totalStats=io.airbyte.config.SyncStats@3d6b5a77[recordsEmitted=0,bytesEmitted=0,sourceStateMessagesEmitted=1,destinationStateMessagesEmitted=1,recordsCommitted=0,meanSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBetweenStateMessageEmittedandCommitted=2,meanSecondsBetweenStateMessageEmittedandCommitted=2,additionalProperties={}],streamStats=[]] 2022-09-19 00:52:14 INFO i.a.w.g.DefaultReplicationWorker(run):276 - Source output at least one state message 2022-09-19 00:52:14 INFO i.a.w.g.DefaultReplicationWorker(run):282 - State capture: Updated state to: Optional[io.airbyte.config.State@6d361f29[state={}]] 2022-09-19 00:52:14 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:14 INFO i.a.w.t.s.ReplicationActivityImpl(lambda$replicate$3):166 - sync summary: io.airbyte.config.StandardSyncOutput@2362bd94[standardSyncSummary=io.airbyte.config.StandardSyncSummary@2a0ff65b[status=completed,recordsSynced=0,bytesSynced=0,startTime=1663548732945,endTime=1663548734958,totalStats=io.airbyte.config.SyncStats@3d6b5a77[recordsEmitted=0,bytesEmitted=0,sourceStateMessagesEmitted=1,destinationStateMessagesEmitted=1,recordsCommitted=0,meanSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBetweenStateMessageEmittedandCommitted=2,meanSecondsBetweenStateMessageEmittedandCommitted=2,additionalProperties={}],streamStats=[]],normalizationSummary=,state=io.airbyte.config.State@6d361f29[state={}],outputCatalog=io.airbyte.protocol.models.ConfiguredAirbyteCatalog@58788ab6[streams=[io.airbyte.protocol.models.ConfiguredAirbyteStream@4dcf9086[stream=io.airbyte.protocol.models.AirbyteStream@7bf70ab6[name=facebookads_insights,jsonSchema={"type":["null","object"],"properties":{"cpc":{"type":["null","number"]},"cpm":{"type":["null","number"]},"cpp":{"type":["null","number"]},"ctr":{"type":["null","number"]},"ad_id":{"type":["null","string"]},"reach":{"type":["null","integer"]},"spend":{"type":["null","number"]},"clicks":{"type":["null","integer"]},"labels":{"type":["null","string"]},"actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"ad_name":{"type":["null","string"]},"adset_id":{"type":["null","string"]},"location":{"type":["null","string"]},"wish_bid":{"type":["null","number"]},"date_stop":{"type":["null","string"],"format":"date"},"frequency":{"type":["null","number"]},"objective":{"type":["null","string"]},"account_id":{"type":["null","string"]},"adset_name":{"type":["null","string"]},"date_start":{"type":["null","string"],"format":"date"},"unique_ctr":{"type":["null","number"]},"auction_bid":{"type":["null","number"]},"buying_type":{"type":["null","string"]},"campaign_id":{"type":["null","string"]},"conversions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"impressions":{"type":["null","integer"]},"website_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"account_name":{"type":["null","string"]},"created_time":{"type":["null","string"],"format":"date"},"social_spend":{"type":["null","number"]},"updated_time":{"type":["null","string"],"format":"date"},"action_values":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"age_targeting":{"type":["null","string"]},"campaign_name":{"type":["null","string"]},"purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"unique_clicks":{"type":["null","integer"]},"unique_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"full_view_reach":{"type":["null","number"]},"outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"quality_ranking":{"type":["null","string"]},"account_currency":{"type":["null","string"]},"ad_click_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"gender_targeting":{"type":["null","string"]},"conversion_values":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_ad_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_thruplay":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"optimization_goal":{"type":["null","string"]},"inline_link_clicks":{"type":["null","integer"]},"video_play_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"attribution_setting":{"type":["null","string"]},"cost_per_conversion":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"outbound_clicks_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"canvas_avg_view_time":{"type":["null","number"]},"cost_per_action_type":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"ad_impression_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_click":{"type":["null","number"]},"full_view_impressions":{"type":["null","number"]},"inline_link_click_ctr":{"type":["null","number"]},"website_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"estimated_ad_recallers":{"type":["null","number"]},"inline_post_engagement":{"type":["null","integer"]},"unique_link_clicks_ctr":{"type":["null","number"]},"unique_outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"auction_competitiveness":{"type":["null","number"]},"canvas_avg_view_percent":{"type":["null","number"]},"catalog_segment_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"conversion_rate_ranking":{"type":["null","string"]},"converted_product_value":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_outbound_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"engagement_rate_ranking":{"type":["null","string"]},"estimated_ad_recall_rate":{"type":["null","number"]},"mobile_app_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_curve_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"unique_inline_link_clicks":{"type":["null","integer"]},"video_p25_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p50_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p75_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p95_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"auction_max_competitor_bid":{"type":["null","number"]},"converted_product_quantity":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_15_sec_video_view":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_inline_link_click":{"type":["null","number"]},"unique_outbound_clicks_ctr":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_p100_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_time_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_action_type":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"unique_inline_link_click_ctr":{"type":["null","number"]},"video_15_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_30_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_unique_outbound_click":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_avg_time_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"cost_per_estimated_ad_recallers":{"type":["null","number"]},"cost_per_inline_post_engagement":{"type":["null","number"]},"cost_per_unique_inline_link_click":{"type":["null","number"]},"instant_experience_clicks_to_open":{"type":["null","number"]},"estimated_ad_recallers_lower_bound":{"type":["null","number"]},"estimated_ad_recallers_upper_bound":{"type":["null","number"]},"instant_experience_clicks_to_start":{"type":["null","number"]},"instant_experience_outbound_clicks":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_retention_graph_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"cost_per_2_sec_continuous_video_view":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"estimated_ad_recall_rate_lower_bound":{"type":["null","number"]},"estimated_ad_recall_rate_upper_bound":{"type":["null","number"]},"video_play_retention_0_to_15s_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"video_continuous_2_sec_watched_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"video_play_retention_20_to_60s_actions":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","array"],"items":{"type":["null","integer"]}},"action_type":{"type":["null","string"]}}}},"qualifying_question_qualify_answer_rate":{"type":["null","number"]},"catalog_segment_value_omni_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value_mobile_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}},"catalog_segment_value_website_purchase_roas":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"value":{"type":["null","number"]},"1d_view":{"type":["null","number"]},"7d_view":{"type":["null","number"]},"1d_click":{"type":["null","number"]},"28d_view":{"type":["null","number"]},"7d_click":{"type":["null","number"]},"28d_click":{"type":["null","number"]},"action_type":{"type":["null","string"]},"action_target_id":{"type":["null","string"]},"action_destination":{"type":["null","string"]}}}}}},supportedSyncModes=[full_refresh, incremental],sourceDefinedCursor=true,defaultCursorField=[date_start],sourceDefinedPrimaryKey=[[date_start], [account_id], [ad_id]],namespace=,additionalProperties={}],syncMode=full_refresh,cursorField=[date_start],destinationSyncMode=overwrite,primaryKey=[[date_start], [account_id], [ad_id]],additionalProperties={}]],additionalProperties={}],failures=[]] 2022-09-19 00:52:14 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):312 - Stopping temporal heartbeating... 2022-09-19 00:52:15 INFO i.a.w.t.TemporalAttemptExecution(get):106 - Docker volume job log path: /tmp/workspace/111/2/logs.log 2022-09-19 00:52:15 INFO i.a.w.t.TemporalAttemptExecution(get):111 - Executing worker wrapper. Airbyte version: 0.40.4 2022-09-19 00:52:15 INFO i.a.w.g.DefaultNormalizationWorker(run):57 - Running normalization. 2022-09-19 00:52:15 INFO i.a.w.n.DefaultNormalizationRunner(runProcess):137 - Running with normalization version: airbyte/normalization-mysql:0.2.20 2022-09-19 00:52:15 INFO i.a.c.i.LineGobbler(voidCall):83 - Checking if airbyte/normalization-mysql:0.2.20 exists... 2022-09-19 00:52:15 INFO i.a.c.i.LineGobbler(voidCall):83 - airbyte/normalization-mysql:0.2.20 was found locally. 2022-09-19 00:52:15 INFO i.a.w.p.DockerProcessFactory(create):119 - Creating docker container = normalization-mysql-normalize-111-2-dnapq with resources io.airbyte.config.ResourceRequirements@12f933d0[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=] 2022-09-19 00:52:15 INFO i.a.w.p.DockerProcessFactory(create):163 - Preparing command: docker run --rm --init -i -w /data/111/2/normalize --log-driver none --name normalization-mysql-normalize-111-2-dnapq --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e AIRBYTE_ROLE= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_VERSION=0.40.4 airbyte/normalization-mysql:0.2.20 run --integration-type mysql --config destination_config.json --catalog destination_catalog.json 2022-09-19 00:52:15 INFO i.a.w.g.DefaultNormalizationWorker(run):81 - Normalization executed in 0 seconds. 2022-09-19 00:52:15 normalization > [FATAL tini (7)] exec /airbyte/entrypoint.sh failed: Exec format error 2022-09-19 00:52:15 INFO i.a.w.t.TemporalAttemptExecution(lambda$getWorkerThread$2):162 - Completing future exceptionally... io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:91) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:26) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:159) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at java.lang.Thread.run(Thread.java:1589) [?:?] 2022-09-19 00:52:15 INFO i.a.w.t.TemporalAttemptExecution(get):132 - Stopping cancellation check scheduling... 2022-09-19 00:52:15 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):312 - Stopping temporal heartbeating... 2022-09-19 00:52:15 WARN i.t.i.a.POJOActivityTaskHandler(activityFailureToResult):307 - Activity failure. ActivityId=c80dd155-6688-3dd6-9624-af009b284198, activityType=Normalize, attempt=1 java.lang.RuntimeException: io.temporal.serviceclient.CheckedExceptionWrapper: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:310) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.normalize(NormalizationActivityImpl.java:80) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at jdk.internal.reflect.DirectMethodHandleAccessor.invoke(DirectMethodHandleAccessor.java:104) ~[?:?] at java.lang.reflect.Method.invoke(Method.java:578) ~[?:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityInboundCallsInterceptor.execute(POJOActivityTaskHandler.java:214) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler$POJOActivityImplementation.execute(POJOActivityTaskHandler.java:180) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.activity.POJOActivityTaskHandler.handle(POJOActivityTaskHandler.java:120) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:204) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.ActivityWorker$TaskHandlerImpl.handle(ActivityWorker.java:164) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.internal.worker.PollTaskExecutor.lambda$process$0(PollTaskExecutor.java:93) ~[temporal-sdk-1.8.1.jar:?] at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144) [?:?] at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642) [?:?] at java.lang.Thread.run(Thread.java:1589) [?:?] Caused by: io.temporal.serviceclient.CheckedExceptionWrapper: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.temporal.serviceclient.CheckedExceptionWrapper.wrap(CheckedExceptionWrapper.java:56) ~[temporal-serviceclient-1.8.1.jar:?] at io.temporal.internal.sync.WorkflowInternal.wrap(WorkflowInternal.java:448) ~[temporal-sdk-1.8.1.jar:?] at io.temporal.activity.Activity.wrap(Activity.java:51) ~[temporal-sdk-1.8.1.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.get(TemporalAttemptExecution.java:136) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.lambda$normalize$3(NormalizationActivityImpl.java:108) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:305) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 12 more Caused by: java.util.concurrent.ExecutionException: io.airbyte.workers.exception.WorkerException: Normalization Failed. at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:396) ~[?:?] at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:2073) ~[?:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.get(TemporalAttemptExecution.java:130) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.sync.NormalizationActivityImpl.lambda$normalize$3(NormalizationActivityImpl.java:108) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalUtils.withBackgroundHeartbeat(TemporalUtils.java:305) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 12 more Caused by: io.airbyte.workers.exception.WorkerException: Normalization Failed. at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:91) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.general.DefaultNormalizationWorker.run(DefaultNormalizationWorker.java:26) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:159) ~[io.airbyte-airbyte-workers-0.40.4.jar:?] ... 1 more