airbytehq / airbyte

The leading data integration platform for ETL / ELT data pipelines from APIs, databases & files to data warehouses, data lakes & data lakehouses. Both self-hosted and Cloud-hosted.
https://airbyte.com
Other
15.48k stars 3.99k forks source link

Source Square: Conversion error in Orders API #30186

Open bloodyburger opened 1 year ago

bloodyburger commented 1 year ago

Connector Name

source-square

Connector Version

1.1.2

What step the error happened?

During the sync

Revelant information

I was able to sync Payments and other details via this connector but while using Orders API, the connector throws error while trying to convert date/time.

Relevant log output


2023-09-06 02:08:53 INFO i.a.c.i.LineGobbler(voidCall):149 - Checking if airbyte/source-square:1.1.2 exists...
2023-09-06 02:08:53 INFO i.a.c.i.LineGobbler(voidCall):149 - airbyte/source-square:1.1.2 was found locally.
2023-09-06 02:08:53 INFO i.a.w.p.DockerProcessFactory(create):139 - Creating docker container = source-square-read-125-1-ufbvx with resources io.airbyte.config.ResourceRequirements@5ccfb9bc[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=,additionalProperties={}] and allowedHosts null
2023-09-06 02:08:53 INFO i.a.w.p.DockerProcessFactory(create):192 - Preparing command: docker run --rm --init -i -w /data/125/1 --log-driver none --name source-square-read-125-1-ufbvx --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e WORKER_CONNECTOR_IMAGE=airbyte/source-square:1.1.2 -e AUTO_DETECT_SCHEMA=true -e LAUNCHDARKLY_KEY= -e SOCAT_KUBE_CPU_REQUEST=0.1 -e SOCAT_KUBE_CPU_LIMIT=2.0 -e USE_STREAM_CAPABLE_STATE=true -e FIELD_SELECTION_WORKSPACES= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_ROLE= -e APPLY_FIELD_SELECTION=false -e WORKER_JOB_ATTEMPT=1 -e OTEL_COLLECTOR_ENDPOINT=http://host.docker.internal:4317 -e FEATURE_FLAG_CLIENT= -e AIRBYTE_VERSION=0.44.5 -e WORKER_JOB_ID=125 airbyte/source-square:1.1.2 read --config source_config.json --catalog source_catalog.json
2023-09-06 02:08:53 INFO i.a.w.i.VersionedAirbyteStreamFactory(create):181 - Reading messages from protocol version 0.2.0
2023-09-06 02:08:53 INFO i.a.w.g.DefaultReplicationWorker(lambda$readFromDstRunnable$4):289 - Destination output thread started.
2023-09-06 02:08:53 INFO i.a.w.i.HeartbeatTimeoutChaperone(runWithHeartbeatThread):94 - Starting source heartbeat check. Will check every 1 minutes.
2023-09-06 02:08:53 INFO i.a.w.g.DefaultReplicationWorker(lambda$readFromSrcAndWriteToDstRunnable$5):334 - Replication thread started.
2023-09-06 02:08:54 destination > INFO i.a.i.d.p.PostgresDestination(main):98 starting destination: class io.airbyte.integrations.destination.postgres.PostgresDestination
2023-09-06 02:08:54 destination > INFO i.a.i.b.IntegrationCliParser(parseOptions):126 integration args: {catalog=destination_catalog.json, write=null, config=destination_config.json}
2023-09-06 02:08:54 destination > INFO i.a.i.b.IntegrationRunner(runInternal):108 Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination
2023-09-06 02:08:54 destination > INFO i.a.i.b.IntegrationRunner(runInternal):109 Command: WRITE
2023-09-06 02:08:54 source > Starting syncing SourceSquare
2023-09-06 02:08:54 destination > INFO i.a.i.b.IntegrationRunner(runInternal):110 Integration config: IntegrationConfig{command=WRITE, configPath='destination_config.json', catalogPath='destination_catalog.json', statePath='null'}
2023-09-06 02:08:54 source > Marking stream items as STARTED
2023-09-06 02:08:54 source > {"type": "TRACE", "trace": {"type": "STREAM_STATUS", "emitted_at": 1693966134586.707, "stream_status": {"stream_descriptor": {"name": "items", "namespace": null}, "status": "STARTED"}}}
2023-09-06 02:08:54 source > Syncing stream: items 
2023-09-06 02:08:54 destination > WARN c.n.s.JsonMetaSchema(newValidator):278 Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword
2023-09-06 02:08:54 destination > WARN c.n.s.JsonMetaSchema(newValidator):278 Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword
2023-09-06 02:08:54 destination > INFO i.a.i.b.s.SshTunnel(getInstance):204 Starting connection with method: NO_TUNNEL
2023-09-06 02:08:54 destination > INFO c.z.h.HikariDataSource(<init>):80 HikariPool-1 - Starting...
2023-09-06 02:08:54 destination > INFO c.z.h.HikariDataSource(<init>):82 HikariPool-1 - Start completed.
2023-09-06 02:08:54 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 Write config: WriteConfig{streamName=items, namespace=null, outputSchemaName=public, tmpTableName=_airbyte_tmp_qib_items, outputTableName=_airbyte_raw_items, syncMode=append_dedup}
2023-09-06 02:08:54 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 Write config: WriteConfig{streamName=modifier_list, namespace=null, outputSchemaName=public, tmpTableName=_airbyte_tmp_fki_modifier_list, outputTableName=_airbyte_raw_modifier_list, syncMode=append_dedup}
2023-09-06 02:08:54 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 Write config: WriteConfig{streamName=orders, namespace=null, outputSchemaName=public, tmpTableName=_airbyte_tmp_olo_orders, outputTableName=_airbyte_raw_orders, syncMode=append_dedup}
2023-09-06 02:08:54 destination > INFO i.a.i.d.b.BufferedStreamConsumer(startTracked):146 class io.airbyte.integrations.destination.buffered_stream_consumer.BufferedStreamConsumer started.
2023-09-06 02:08:54 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):134 Preparing raw tables in destination started for 3 streams
2023-09-06 02:08:54 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):139 Preparing raw table in destination started for stream items. schema: public, table name: _airbyte_raw_items
2023-09-06 02:08:56 source > Marking stream items as RUNNING
2023-09-06 02:08:56 source > {"type": "TRACE", "trace": {"type": "STREAM_STATUS", "emitted_at": 1693966136448.824, "stream_status": {"stream_descriptor": {"name": "items", "namespace": null}, "status": "RUNNING"}}}
2023-09-06 02:08:57 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):139 Preparing raw table in destination started for stream modifier_list. schema: public, table name: _airbyte_raw_modifier_list
2023-09-06 02:08:57 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):139 Preparing raw table in destination started for stream orders. schema: public, table name: _airbyte_raw_orders
2023-09-06 02:08:57 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):152 Preparing raw tables in destination completed.
2023-09-06 02:09:02 source > Encountered an exception while reading stream items
Traceback (most recent call last):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 122, in read
    yield from self._read_stream(
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 197, in _read_stream
    for record in record_iterator:
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 266, in _read_incremental
    for message_counter, record_data_or_message in enumerate(records, start=1):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/declarative_stream.py", line 99, in read_records
    yield from self.retriever.read_records(sync_mode, cursor_field, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 414, in read_records
    most_recent_record_from_slice = self._get_most_recent_record(most_recent_record_from_slice, stream_data, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 428, in _get_most_recent_record
    return current_most_recent if self.cursor.is_greater_than_or_equal(current_most_recent, record) else record
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 274, in is_greater_than_or_equal
    return self.parse_date(first_cursor_value) >= self.parse_date(second_cursor_value)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 187, in parse_date
    return self._parser.parse(date, self.datetime_format)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/datetime/datetime_parser.py", line 29, in parse
    parsed_datetime = datetime.datetime.strptime(str(date), format)
  File "/usr/local/lib/python3.9/_strptime.py", line 568, in _strptime_datetime
    tt, fraction, gmtoff_fraction = _strptime(data_string, format)
  File "/usr/local/lib/python3.9/_strptime.py", line 349, in _strptime
    raise ValueError("time data %r does not match format %r" %
ValueError: time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'
2023-09-06 02:09:02 source > Marking stream items as STOPPED
2023-09-06 02:09:02 source > {"type": "TRACE", "trace": {"type": "STREAM_STATUS", "emitted_at": 1693966142203.736, "stream_status": {"stream_descriptor": {"name": "items", "namespace": null}, "status": "INCOMPLETE"}}}
2023-09-06 02:09:02 source > Finished syncing items
2023-09-06 02:09:02 source > SourceSquare runtimes:
Syncing stream items 0:00:07.617358
2023-09-06 02:09:02 source > time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'
Traceback (most recent call last):
  File "/airbyte/integration_code/main.py", line 13, in <module>
    launch(source, sys.argv[1:])
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 185, in launch
    for message in source_entrypoint.run(parsed_args):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 115, in run
    yield from map(AirbyteEntrypoint.airbyte_message_to_string, self.read(source_spec, config, config_catalog, state))
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 155, in read
    yield from self.source.read(self.logger, config, catalog, state)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/manifest_declarative_source.py", line 136, in read
    yield from super().read(logger, config, catalog, state)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 142, in read
    raise e
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 122, in read
    yield from self._read_stream(
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 197, in _read_stream
    for record in record_iterator:
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 266, in _read_incremental
    for message_counter, record_data_or_message in enumerate(records, start=1):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/declarative_stream.py", line 99, in read_records
    yield from self.retriever.read_records(sync_mode, cursor_field, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 414, in read_records
    most_recent_record_from_slice = self._get_most_recent_record(most_recent_record_from_slice, stream_data, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 428, in _get_most_recent_record
    return current_most_recent if self.cursor.is_greater_than_or_equal(current_most_recent, record) else record
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 274, in is_greater_than_or_equal
    return self.parse_date(first_cursor_value) >= self.parse_date(second_cursor_value)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 187, in parse_date
    return self._parser.parse(date, self.datetime_format)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/datetime/datetime_parser.py", line 29, in parse
    parsed_datetime = datetime.datetime.strptime(str(date), format)
  File "/usr/local/lib/python3.9/_strptime.py", line 568, in _strptime_datetime
    tt, fraction, gmtoff_fraction = _strptime(data_string, format)
  File "/usr/local/lib/python3.9/_strptime.py", line 349, in _strptime
    raise ValueError("time data %r does not match format %r" %
ValueError: time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'
2023-09-06 02:09:02 INFO i.a.w.g.DefaultReplicationWorker(lambda$readFromSrcAndWriteToDstRunnable$5):361 - Source has no more messages, closing connection.
2023-09-06 02:09:02 destination > INFO i.a.i.b.FailureTrackingAirbyteMessageConsumer(close):80 Airbyte message consumer: succeeded.
2023-09-06 02:09:02 destination > INFO i.a.i.d.b.BufferedStreamConsumer(close):257 executing on success close procedure.
2023-09-06 02:09:02 destination > INFO i.a.i.d.r.InMemoryRecordBufferingStrategy(flushAll):85 Flushing items: 1272 records (6 MB)
2023-09-06 02:09:04 destination > INFO i.a.i.d.r.InMemoryRecordBufferingStrategy(flushAll):91 Flushing completed for items
2023-09-06 02:09:04 destination > INFO i.a.i.d.j.SqlOperations(onDestinationCloseOperations):154 No onDestinationCloseOperations required for this destination.
2023-09-06 02:09:04 destination > INFO i.a.i.b.IntegrationRunner(runInternal):186 Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination
2023-09-06 02:09:04 destination > INFO i.a.i.d.p.PostgresDestination(main):100 completed destination: class io.airbyte.integrations.destination.postgres.PostgresDestination
2023-09-06 02:09:04 ERROR i.a.w.g.DefaultReplicationWorker(replicate):260 - Sync worker failed.
io.airbyte.workers.internal.exception.SourceException: Source didn't exit properly - check the logs!
    at io.airbyte.workers.general.DefaultReplicationWorker.lambda$readFromSrcAndWriteToDstRunnable$5(DefaultReplicationWorker.java:365) ~[io.airbyte-airbyte-commons-worker-0.44.5.jar:?]
    at java.util.concurrent.CompletableFuture$AsyncRun.run(CompletableFuture.java:1804) ~[?:?]
    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) ~[?:?]
    Suppressed: io.airbyte.workers.exception.WorkerException: Source process exit with code 1. This warning is normal if the job was cancelled.
        at io.airbyte.workers.internal.DefaultAirbyteSource.close(DefaultAirbyteSource.java:150) ~[io.airbyte-airbyte-commons-worker-0.44.5.jar:?]
        at io.airbyte.workers.general.DefaultReplicationWorker.replicate(DefaultReplicationWorker.java:200) ~[io.airbyte-airbyte-commons-worker-0.44.5.jar:?]
        at io.airbyte.workers.general.DefaultReplicationWorker.run(DefaultReplicationWorker.java:176) ~[io.airbyte-airbyte-commons-worker-0.44.5.jar:?]
        at io.airbyte.workers.general.DefaultReplicationWorker.run(DefaultReplicationWorker.java:79) ~[io.airbyte-airbyte-commons-worker-0.44.5.jar:?]
        at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$5(TemporalAttemptExecution.java:195) ~[io.airbyte-airbyte-workers-0.44.5.jar:?]
        at java.lang.Thread.run(Thread.java:1589) ~[?:?]
Caused by: io.airbyte.workers.exception.WorkerException: Source process exit with code 1. This warning is normal if the job was cancelled.
    at io.airbyte.workers.internal.DefaultAirbyteSource.close(DefaultAirbyteSource.java:150) ~[io.airbyte-airbyte-commons-worker-0.44.5.jar:?]
    at io.airbyte.workers.general.DefaultReplicationWorker.lambda$readFromSrcAndWriteToDstRunnable$5(DefaultReplicationWorker.java:363) ~[io.airbyte-airbyte-commons-worker-0.44.5.jar:?]
    ... 4 more
2023-09-06 02:09:04 INFO i.a.w.g.DefaultReplicationWorker(getReplicationOutput):449 - sync summary: {
  "status" : "failed",
  "recordsSynced" : 1272,
  "bytesSynced" : 1591296,
  "startTime" : 1693966133541,
  "endTime" : 1693966144516,
  "totalStats" : {
    "bytesCommitted" : 0,
    "bytesEmitted" : 1591296,
    "destinationStateMessagesEmitted" : 0,
    "destinationWriteEndTime" : 1693966144516,
    "destinationWriteStartTime" : 1693966133587,
    "meanSecondsBeforeSourceStateMessageEmitted" : 0,
    "maxSecondsBeforeSourceStateMessageEmitted" : 0,
    "maxSecondsBetweenStateMessageEmittedandCommitted" : 0,
    "meanSecondsBetweenStateMessageEmittedandCommitted" : 0,
    "recordsEmitted" : 1272,
    "recordsCommitted" : 0,
    "replicationEndTime" : 1693966144516,
    "replicationStartTime" : 1693966133541,
    "sourceReadEndTime" : 0,
    "sourceReadStartTime" : 1693966133568,
    "sourceStateMessagesEmitted" : 0
  },
  "streamStats" : [ {
    "streamName" : "items",
    "stats" : {
      "bytesEmitted" : 1591296,
      "recordsEmitted" : 1272
    }
  } ]
}
2023-09-06 02:09:04 INFO i.a.w.g.DefaultReplicationWorker(getReplicationOutput):450 - failures: [ {
  "failureOrigin" : "source",
  "failureType" : "system_error",
  "internalMessage" : "time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'",
  "externalMessage" : "Something went wrong in the connector. See the logs for more details.",
  "metadata" : {
    "attemptNumber" : 1,
    "jobId" : 125,
    "from_trace_message" : true,
    "connector_command" : "read"
  },
  "stacktrace" : "Traceback (most recent call last):\n  File \"/airbyte/integration_code/main.py\", line 13, in <module>\n    launch(source, sys.argv[1:])\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py\", line 185, in launch\n    for message in source_entrypoint.run(parsed_args):\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py\", line 115, in run\n    yield from map(AirbyteEntrypoint.airbyte_message_to_string, self.read(source_spec, config, config_catalog, state))\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py\", line 155, in read\n    yield from self.source.read(self.logger, config, catalog, state)\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/manifest_declarative_source.py\", line 136, in read\n    yield from super().read(logger, config, catalog, state)\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py\", line 142, in read\n    raise e\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py\", line 122, in read\n    yield from self._read_stream(\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py\", line 197, in _read_stream\n    for record in record_iterator:\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py\", line 266, in _read_incremental\n    for message_counter, record_data_or_message in enumerate(records, start=1):\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/declarative_stream.py\", line 99, in read_records\n    yield from self.retriever.read_records(sync_mode, cursor_field, stream_slice)\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py\", line 414, in read_records\n    most_recent_record_from_slice = self._get_most_recent_record(most_recent_record_from_slice, stream_data, stream_slice)\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py\", line 428, in _get_most_recent_record\n    return current_most_recent if self.cursor.is_greater_than_or_equal(current_most_recent, record) else record\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py\", line 274, in is_greater_than_or_equal\n    return self.parse_date(first_cursor_value) >= self.parse_date(second_cursor_value)\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py\", line 187, in parse_date\n    return self._parser.parse(date, self.datetime_format)\n  File \"/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/datetime/datetime_parser.py\", line 29, in parse\n    parsed_datetime = datetime.datetime.strptime(str(date), format)\n  File \"/usr/local/lib/python3.9/_strptime.py\", line 568, in _strptime_datetime\n    tt, fraction, gmtoff_fraction = _strptime(data_string, format)\n  File \"/usr/local/lib/python3.9/_strptime.py\", line 349, in _strptime\n    raise ValueError(\"time data %r does not match format %r\" %\nValueError: time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'\n",
  "timestamp" : 1693966142204
}, {
  "failureOrigin" : "source",
  "internalMessage" : "Source didn't exit properly - check the logs!",
  "externalMessage" : "Something went wrong within the source connector",
  "metadata" : {
    "attemptNumber" : 1,
    "jobId" : 125,
    "connector_command" : "read"
  },
  "stacktrace" : "io.airbyte.workers.internal.exception.SourceException: Source didn't exit properly - check the logs!\n\tat io.airbyte.workers.general.DefaultReplicationWorker.lambda$readFromSrcAndWriteToDstRunnable$5(DefaultReplicationWorker.java:365)\n\tat java.base/java.util.concurrent.CompletableFuture$AsyncRun.run(CompletableFuture.java:1804)\n\tat java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144)\n\tat java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642)\n\tat java.base/java.lang.Thread.run(Thread.java:1589)\nCaused by: io.airbyte.workers.exception.WorkerException: Source process exit with code 1. This warning is normal if the job was cancelled.\n\tat io.airbyte.workers.internal.DefaultAirbyteSource.close(DefaultAirbyteSource.java:150)\n\tat io.airbyte.workers.general.DefaultReplicationWorker.lambda$readFromSrcAndWriteToDstRunnable$5(DefaultReplicationWorker.java:363)\n\t... 4 more\n",
  "timestamp" : 1693966142520
} ]
2023-09-06 02:09:04 INFO i.a.w.t.TemporalAttemptExecution(get):163 - Stopping cancellation check scheduling...
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- END REPLICATION -----
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:09:04 INFO i.a.w.t.s.ReplicationActivityImpl(lambda$replicate$3):159 - sync summary: io.airbyte.config.StandardSyncOutput@4746b23[standardSyncSummary=io.airbyte.config.StandardSyncSummary@2d083261[status=failed,recordsSynced=1272,bytesSynced=1591296,startTime=1693966133541,endTime=1693966144516,totalStats=io.airbyte.config.SyncStats@4aba6e69[bytesCommitted=0,bytesEmitted=1591296,destinationStateMessagesEmitted=0,destinationWriteEndTime=1693966144516,destinationWriteStartTime=1693966133587,estimatedBytes=<null>,estimatedRecords=<null>,meanSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBeforeSourceStateMessageEmitted=0,maxSecondsBetweenStateMessageEmittedandCommitted=0,meanSecondsBetweenStateMessageEmittedandCommitted=0,recordsEmitted=1272,recordsCommitted=0,replicationEndTime=1693966144516,replicationStartTime=1693966133541,sourceReadEndTime=0,sourceReadStartTime=1693966133568,sourceStateMessagesEmitted=0,additionalProperties={}],streamStats=[io.airbyte.config.StreamSyncStats@7a4bebe2[streamName=items,streamNamespace=<null>,stats=io.airbyte.config.SyncStats@5dc1aafb[bytesCommitted=<null>,bytesEmitted=1591296,destinationStateMessagesEmitted=<null>,destinationWriteEndTime=<null>,destinationWriteStartTime=<null>,estimatedBytes=<null>,estimatedRecords=<null>,meanSecondsBeforeSourceStateMessageEmitted=<null>,maxSecondsBeforeSourceStateMessageEmitted=<null>,maxSecondsBetweenStateMessageEmittedandCommitted=<null>,meanSecondsBetweenStateMessageEmittedandCommitted=<null>,recordsEmitted=1272,recordsCommitted=<null>,replicationEndTime=<null>,replicationStartTime=<null>,sourceReadEndTime=<null>,sourceReadStartTime=<null>,sourceStateMessagesEmitted=<null>,additionalProperties={}],additionalProperties={}]],additionalProperties={}],normalizationSummary=<null>,webhookOperationSummary=<null>,state=<null>,outputCatalog=io.airbyte.protocol.models.ConfiguredAirbyteCatalog@31360018[streams=[io.airbyte.protocol.models.ConfiguredAirbyteStream@28e6e971[stream=io.airbyte.protocol.models.AirbyteStream@d570374[name=items,jsonSchema={"type":["null","object"],"properties":{"present_at_all_locations":{"type":["null","boolean"]},"custom_attribute_values":{"type":["null","object"]},"is_deleted":{"type":["null","boolean"]},"updated_at":{"type":["null","string"]},"id":{"type":["null","string"]},"type":{"type":["null","string"]},"image_id":{"type":["null","string"]},"version":{"type":["null","integer"]},"present_at_location_ids":{"type":["null","array"],"items":{"type":["null","string"]}},"item_data":{"type":["null","object"],"properties":{"item_options":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"item_option_id":{"type":["null","string"]}}}},"product_type":{"type":["null","string"]},"tax_ids":{"type":["null","array"],"items":{"type":["null","string"]}},"visibility":{"type":["null","string"]},"category_id":{"type":["null","string"]},"variations":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"present_at_all_locations":{"type":["null","boolean"]},"is_deleted":{"type":["null","boolean"]},"updated_at":{"type":["null","string"]},"item_variation_data":{"type":["null","object"],"properties":{"pricing_type":{"type":["null","string"]},"item_option_values":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"item_option_id":{"type":["null","string"]},"item_option_value_id":{"type":["null","string"]}}}},"price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"item_id":{"type":["null","string"]},"name":{"type":["null","string"]},"location_overrides":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"track_inventory":{"type":["null","boolean"]},"location_id":{"type":["null","string"]}}}},"sku":{"type":["null","string"]},"ordinal":{"type":["null","integer"]}}},"id":{"type":["null","string"]},"type":{"type":["null","string"]},"version":{"type":["null","integer"]},"present_at_location_ids":{"type":["null","array"],"items":{"type":["null","string"]}}}}},"name":{"type":["null","string"]},"ecom_visibility":{"type":["null","string"]},"description":{"type":["null","string"]},"modifier_list_info":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"visibility":{"type":["null","string"]},"max_selected_modifiers":{"type":["null","integer"]},"modifier_list_id":{"type":["null","string"]},"enabled":{"type":["null","boolean"]},"min_selected_modifiers":{"type":["null","integer"]}}}},"skip_modifier_screen":{"type":["null","boolean"]}}}}},supportedSyncModes=[full_refresh, incremental],sourceDefinedCursor=true,defaultCursorField=[updated_at],sourceDefinedPrimaryKey=[],namespace=<null>,additionalProperties={}],syncMode=incremental,cursorField=[updated_at],destinationSyncMode=append_dedup,primaryKey=[[updated_at], [id]],additionalProperties={}], io.airbyte.protocol.models.ConfiguredAirbyteStream@5d91f657[stream=io.airbyte.protocol.models.AirbyteStream@5c261b3d[name=modifier_list,jsonSchema={"type":["null","object"],"properties":{"present_at_all_locations":{"type":["null","boolean"]},"is_deleted":{"type":["null","boolean"]},"updated_at":{"type":["null","string"]},"modifier_list_data":{"type":["null","object"],"properties":{"selection_type":{"type":["null","string"]},"name":{"type":["null","string"]},"modifiers":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"present_at_all_locations":{"type":["null","boolean"]},"is_deleted":{"type":["null","boolean"]},"updated_at":{"type":["null","string"]},"id":{"type":["null","string"]},"type":{"type":["null","string"]},"version":{"type":["null","integer"]},"modifier_data":{"type":["null","object"],"properties":{"price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"on_by_default":{"type":["null","boolean"]},"name":{"type":["null","string"]},"modifier_list_id":{"type":["null","string"]},"ordinal":{"type":["null","integer"]}}}}}}}},"id":{"type":["null","string"]},"type":{"type":["null","string"]},"version":{"type":["null","integer"]}}},supportedSyncModes=[full_refresh, incremental],sourceDefinedCursor=true,defaultCursorField=[updated_at],sourceDefinedPrimaryKey=[],namespace=<null>,additionalProperties={}],syncMode=incremental,cursorField=[updated_at],destinationSyncMode=append_dedup,primaryKey=[[updated_at], [id]],additionalProperties={}], io.airbyte.protocol.models.ConfiguredAirbyteStream@4394dca9[stream=io.airbyte.protocol.models.AirbyteStream@76ed3b0c[name=orders,jsonSchema={"type":["null","object"],"properties":{"closed_at":{"type":["null","string"]},"total_tax_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"total_service_charge_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"service_charges":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"applied_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"calculation_phase":{"type":["null","string"]},"total_tax_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"taxable":{"type":["null","boolean"]},"name":{"type":["null","string"]},"amount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"total_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}}}}},"total_tip_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"taxes":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"applied_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"catalog_object_id":{"type":["null","string"]},"scope":{"type":["null","string"]},"percentage":{"type":["null","string"]},"name":{"type":["null","string"]},"type":{"type":["null","string"]}}}},"created_at":{"type":["null","string"]},"source":{"type":["null","object"],"properties":{"name":{"type":["null","string"]}}},"line_items":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"note":{"type":["null","string"]},"catalog_object_id":{"type":["null","string"]},"quantity":{"type":["null","string"]},"total_tax_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"item_type":{"type":["null","string"]},"variation_name":{"type":["null","string"]},"modifiers":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"catalog_object_id":{"type":["null","string"]},"total_price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"base_price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"name":{"type":["null","string"]}}}},"gross_sales_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"uid":{"type":["null","string"]},"variation_total_price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"base_price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"name":{"type":["null","string"]},"total_discount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"total_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"applied_taxes":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"applied_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"tax_uid":{"type":["null","string"]}}}},"applied_discounts":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"applied_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"discount_uid":{"type":["null","string"]}}}}}}},"version":{"type":["null","integer"]},"location_id":{"type":["null","string"]},"refunds":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"transaction_id":{"type":["null","string"]},"reason":{"type":["null","string"]},"tender_id":{"type":["null","string"]},"created_at":{"type":["null","string"]},"amount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"id":{"type":["null","string"]},"location_id":{"type":["null","string"]},"status":{"type":["null","string"]}}}},"fulfillments":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"pickup_details":{"type":["null","object"],"properties":{"note":{"type":["null","string"]},"expires_at":{"type":["null","string"]},"schedule_type":{"type":["null","string"]},"ready_at":{"type":["null","string"]},"pickup_at":{"type":["null","string"]},"picked_up_at":{"type":["null","string"]},"recipient":{"type":["null","object"],"properties":{"phone_number":{"type":["null","string"]},"display_name":{"type":["null","string"]}}},"auto_complete_duration":{"type":["null","string"]},"placed_at":{"type":["null","string"]},"accepted_at":{"type":["null","string"]}}},"shipment_details":{"type":["null","object"],"properties":{"packaged_at":{"type":["null","string"]},"carrier":{"type":["null","string"]},"shipped_at":{"type":["null","string"]},"expected_shipped_at":{"type":["null","string"]},"recipient":{"type":["null","object"],"properties":{"address":{"type":["null","object"],"properties":{"locality":{"type":["null","string"]},"address_line_1":{"type":["null","string"]},"administrative_district_level_1":{"type":["null","string"]},"postal_code":{"type":["null","string"]}}},"phone_number":{"type":["null","string"]},"display_name":{"type":["null","string"]}}},"in_progress_at":{"type":["null","string"]},"tracking_number":{"type":["null","string"]},"placed_at":{"type":["null","string"]}}},"state":{"type":["null","string"]},"type":{"type":["null","string"]}}}},"discounts":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"applied_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"scope":{"type":["null","string"]},"percentage":{"type":["null","string"]},"name":{"type":["null","string"]},"type":{"type":["null","string"]}}}},"updated_at":{"type":["null","string"]},"tenders":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"card_details":{"type":["null","object"],"properties":{"entry_method":{"type":["null","string"]},"card":{"type":["null","object"],"properties":{"last_4":{"type":["null","string"]},"card_brand":{"type":["null","string"]},"fingerprint":{"type":["null","string"]}}},"status":{"type":["null","string"]}}},"transaction_id":{"type":["null","string"]},"note":{"type":["null","string"]},"payment_id":{"type":["null","string"]},"cash_details":{"type":["null","object"],"properties":{"buyer_tendered_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"change_back_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}}}},"created_at":{"type":["null","string"]},"amount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"id":{"type":["null","string"]},"type":{"type":["null","string"]},"location_id":{"type":["null","string"]}}}},"total_discount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"net_amounts":{"type":["null","object"],"properties":{"discount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"tip_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"total_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"service_charge_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"tax_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}}}},"return_amounts":{"type":["null","object"],"properties":{"discount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"tip_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"total_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"service_charge_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"tax_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}}}},"returns":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"return_line_items":{"type":["null","array"],"items":{"type":["null","object"],"properties":{"uid":{"type":["null","string"]},"quantity":{"type":["null","string"]},"total_tax_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"gross_return_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"variation_total_price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"base_price_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"item_type":{"type":["null","string"]},"total_discount_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}},"total_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}}}}},"source_order_id":{"type":["null","string"]}}}},"id":{"type":["null","string"]},"state":{"type":["null","string"]},"total_money":{"type":["null","object"],"properties":{"amount":{"type":["null","integer"]},"currency":{"type":["null","string"]}}}}},supportedSyncModes=[full_refresh, incremental],sourceDefinedCursor=true,defaultCursorField=[updated_at],sourceDefinedPrimaryKey=[[id]],namespace=<null>,additionalProperties={}],syncMode=incremental,cursorField=[updated_at],destinationSyncMode=append_dedup,primaryKey=[[id]],additionalProperties={}]],additionalProperties={}],failures=[io.airbyte.config.FailureReason@249c58c8[failureOrigin=source,failureType=system_error,internalMessage=time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ',externalMessage=Something went wrong in the connector. See the logs for more details.,metadata=io.airbyte.config.Metadata@480f5095[additionalProperties={attemptNumber=1, jobId=125, from_trace_message=true, connector_command=read}],stacktrace=Traceback (most recent call last):
  File "/airbyte/integration_code/main.py", line 13, in <module>
    launch(source, sys.argv[1:])
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 185, in launch
    for message in source_entrypoint.run(parsed_args):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 115, in run
    yield from map(AirbyteEntrypoint.airbyte_message_to_string, self.read(source_spec, config, config_catalog, state))
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 155, in read
    yield from self.source.read(self.logger, config, catalog, state)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/manifest_declarative_source.py", line 136, in read
    yield from super().read(logger, config, catalog, state)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 142, in read
    raise e
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 122, in read
    yield from self._read_stream(
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 197, in _read_stream
    for record in record_iterator:
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 266, in _read_incremental
    for message_counter, record_data_or_message in enumerate(records, start=1):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/declarative_stream.py", line 99, in read_records
    yield from self.retriever.read_records(sync_mode, cursor_field, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 414, in read_records
    most_recent_record_from_slice = self._get_most_recent_record(most_recent_record_from_slice, stream_data, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 428, in _get_most_recent_record
    return current_most_recent if self.cursor.is_greater_than_or_equal(current_most_recent, record) else record
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 274, in is_greater_than_or_equal
    return self.parse_date(first_cursor_value) >= self.parse_date(second_cursor_value)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 187, in parse_date
    return self._parser.parse(date, self.datetime_format)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/datetime/datetime_parser.py", line 29, in parse
    parsed_datetime = datetime.datetime.strptime(str(date), format)
  File "/usr/local/lib/python3.9/_strptime.py", line 568, in _strptime_datetime
    tt, fraction, gmtoff_fraction = _strptime(data_string, format)
  File "/usr/local/lib/python3.9/_strptime.py", line 349, in _strptime
    raise ValueError("time data %r does not match format %r" %
ValueError: time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'
,retryable=<null>,timestamp=1693966142204,additionalProperties={}], io.airbyte.config.FailureReason@2d9bbca9[failureOrigin=source,failureType=<null>,internalMessage=Source didn't exit properly - check the logs!,externalMessage=Something went wrong within the source connector,metadata=io.airbyte.config.Metadata@32b1c74d[additionalProperties={attemptNumber=1, jobId=125, connector_command=read}],stacktrace=io.airbyte.workers.internal.exception.SourceException: Source didn't exit properly - check the logs!
    at io.airbyte.workers.general.DefaultReplicationWorker.lambda$readFromSrcAndWriteToDstRunnable$5(DefaultReplicationWorker.java:365)
    at java.base/java.util.concurrent.CompletableFuture$AsyncRun.run(CompletableFuture.java:1804)
    at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1144)
    at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:642)
    at java.base/java.lang.Thread.run(Thread.java:1589)
Caused by: io.airbyte.workers.exception.WorkerException: Source process exit with code 1. This warning is normal if the job was cancelled.
    at io.airbyte.workers.internal.DefaultAirbyteSource.close(DefaultAirbyteSource.java:150)
    at io.airbyte.workers.general.DefaultReplicationWorker.lambda$readFromSrcAndWriteToDstRunnable$5(DefaultReplicationWorker.java:363)
    ... 4 more
,retryable=<null>,timestamp=1693966142520,additionalProperties={}]],commitStateAsap=true,additionalProperties={}]
2023-09-06 02:09:04 INFO i.a.w.t.s.ReplicationActivityImpl(lambda$replicate$3):164 - Sync summary length: 22577
2023-09-06 02:09:04 INFO i.a.c.t.TemporalUtils(withBackgroundHeartbeat):307 - Stopping temporal heartbeating...
2023-09-06 02:09:04 INFO i.a.w.t.s.NormalizationActivityImpl(lambda$normalize$3):128 - Using protocol v0
2023-09-06 02:09:04 INFO i.a.w.t.s.NormalizationActivityImpl(lambda$normalize$3):148 - Using normalization: airbyte/normalization:0.4.3
2023-09-06 02:09:04 INFO i.a.w.t.TemporalAttemptExecution(get):136 - Docker volume job log path: /tmp/workspace/125/1/logs.log
2023-09-06 02:09:04 INFO i.a.w.t.TemporalAttemptExecution(get):141 - Executing worker wrapper. Airbyte version: 0.44.5
2023-09-06 02:09:04 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to save workflow id for cancellation
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- START DEFAULT NORMALIZATION -----
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:09:04 INFO i.a.w.n.DefaultNormalizationRunner(runProcess):130 - Running with normalization version: airbyte/normalization:0.4.3
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - Checking if airbyte/normalization:0.4.3 exists...
2023-09-06 02:09:04 INFO i.a.c.i.LineGobbler(voidCall):149 - airbyte/normalization:0.4.3 was found locally.
2023-09-06 02:09:04 INFO i.a.w.p.DockerProcessFactory(create):139 - Creating docker container = normalization-normalize-125-1-jcsss with resources io.airbyte.config.ResourceRequirements@2408193d[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=,additionalProperties={}] and allowedHosts null
2023-09-06 02:09:04 INFO i.a.w.p.DockerProcessFactory(create):192 - Preparing command: docker run --rm --init -i -w /data/125/1/normalize --log-driver none --name normalization-normalize-125-1-jcsss --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_ROLE= -e AIRBYTE_VERSION=0.44.5 airbyte/normalization:0.4.3 run --integration-type postgres --config destination_config.json --catalog destination_catalog.json
2023-09-06 02:09:04 normalization > Running: transform-config --config destination_config.json --integration-type postgres --out /data/125/1/normalize
2023-09-06 02:09:05 normalization > Namespace(config='destination_config.json', integration_type=<DestinationType.POSTGRES: 'postgres'>, out='/data/125/1/normalize')
2023-09-06 02:09:05 normalization > transform_postgres
2023-09-06 02:09:05 normalization > Running: transform-catalog --integration-type postgres --profile-config-dir /data/125/1/normalize --catalog destination_catalog.json --out /data/125/1/normalize/models/generated/ --json-column _airbyte_data
2023-09-06 02:09:05 normalization > Processing destination_catalog.json...
2023-09-06 02:09:05 normalization > Truncating items_item_data_variations_item_variation_data (#46) to items_item_data_vari_s_item_variation_data (#43)
2023-09-06 02:09:05 normalization > Truncating items_item_data_variations_item_variation_data_item_option_values (#65) to items_item_data_vari_ta_item_option_values (#43)
2023-09-06 02:09:05 normalization > Truncating items_item_data_variations_item_variation_data_price_money (#58) to items_item_data_vari_tion_data_price_money (#43)
2023-09-06 02:09:05 normalization > Truncating items_item_data_variations_item_variation_data_location_overrides (#65) to items_item_data_vari_ta_location_overrides (#43)
2023-09-06 02:09:05 normalization > Truncating items_item_data_variations_present_at_location_ids (#50) to items_item_data_vari_esent_at_location_ids (#43)
2023-09-06 02:09:05 normalization > Truncating modifier_list_modifier_list_data_modifiers_modifier_data (#56) to modifier_list_modifi_difiers_modifier_data (#43)
2023-09-06 02:09:05 normalization > Truncating modifier_list_modifier_list_data_modifiers_modifier_data_price_money (#68) to modifier_list_modifi_fier_data_price_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_line_items_modifiers_total_price_money (#45) to orders_line_items_mo_ers_total_price_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_line_items_modifiers_base_price_money (#44) to orders_line_items_mo_iers_base_price_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_line_items_variation_total_price_money (#45) to orders_line_items_va_ion_total_price_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_line_items_applied_taxes_applied_money (#45) to orders_line_items_ap_d_taxes_applied_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_line_items_applied_discounts_applied_money (#49) to orders_line_items_ap_scounts_applied_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_fulfillments_pickup_details_recipient (#44) to orders_fulfillments__kup_details_recipient (#43)
2023-09-06 02:09:05 normalization > Truncating orders_fulfillments_shipment_details_recipient (#46) to orders_fulfillments__ent_details_recipient (#43)
2023-09-06 02:09:05 normalization > Truncating orders_fulfillments_shipment_details_recipient_address (#54) to orders_fulfillments__ils_recipient_address (#43)
2023-09-06 02:09:05 normalization > Truncating orders_tenders_cash_details_buyer_tendered_money (#48) to orders_tenders_cash___buyer_tendered_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_tenders_cash_details_change_back_money (#45) to orders_tenders_cash__ils_change_back_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_returns_return_line_items_total_tax_money (#48) to orders_returns_retur_items_total_tax_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_returns_return_line_items_gross_return_money (#51) to orders_returns_retur_ms_gross_return_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_returns_return_line_items_variation_total_price_money (#60) to orders_returns_retur_ion_total_price_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_returns_return_line_items_base_price_money (#49) to orders_returns_retur_tems_base_price_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_returns_return_line_items_total_discount_money (#53) to orders_returns_retur__total_discount_money (#43)
2023-09-06 02:09:05 normalization > Truncating orders_returns_return_line_items_total_money (#44) to orders_returns_retur_ine_items_total_money (#43)
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/items_ab1.sql from items
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/items_ab2.sql from items
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/items_stg.sql from items
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/scd/public/items_scd.sql from items
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/items.sql from items
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/modifier_list_ab1.sql from modifier_list
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/modifier_list_ab2.sql from modifier_list
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/modifier_list_stg.sql from modifier_list
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/scd/public/modifier_list_scd.sql from modifier_list
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/modifier_list.sql from modifier_list
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_ab1.sql from orders
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_ab2.sql from orders
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_stg.sql from orders
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/scd/public/orders_scd.sql from orders
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders.sql from orders
2023-09-06 02:09:05 normalization >   Ignoring stream 'present_at_location_ids' from items/present_at_location_ids because properties list is empty
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/items_item_data_ab1.sql from items/item_data
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/items_item_data_ab2.sql from items/item_data
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/items_item_data_ab3.sql from items/item_data
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/items_item_data.sql from items/item_data
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/modifier_list_modifier_list_data_ab1.sql from modifier_list/modifier_list_data
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/modifier_list_modifier_list_data_ab2.sql from modifier_list/modifier_list_data
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/modifier_list_modifier_list_data_ab3.sql from modifier_list/modifier_list_data
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/modifier_list_modifier_list_data.sql from modifier_list/modifier_list_data
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_tax_money_ab1.sql from orders/total_tax_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_tax_money_ab2.sql from orders/total_tax_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_tax_money_ab3.sql from orders/total_tax_money
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_total_tax_money.sql from orders/total_tax_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_service_charge_money_ab1.sql from orders/total_service_charge_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_service_charge_money_ab2.sql from orders/total_service_charge_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_service_charge_money_ab3.sql from orders/total_service_charge_money
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_total_service_charge_money.sql from orders/total_service_charge_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_service_charges_ab1.sql from orders/service_charges
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_service_charges_ab2.sql from orders/service_charges
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_service_charges_ab3.sql from orders/service_charges
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_service_charges.sql from orders/service_charges
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_tip_money_ab1.sql from orders/total_tip_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_tip_money_ab2.sql from orders/total_tip_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_total_tip_money_ab3.sql from orders/total_tip_money
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_total_tip_money.sql from orders/total_tip_money
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_taxes_ab1.sql from orders/taxes
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_taxes_ab2.sql from orders/taxes
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_taxes_ab3.sql from orders/taxes
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_taxes.sql from orders/taxes
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_source_ab1.sql from orders/source
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_source_ab2.sql from orders/source
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_source_ab3.sql from orders/source
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_source.sql from orders/source
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_line_items_ab1.sql from orders/line_items
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_line_items_ab2.sql from orders/line_items
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_line_items_ab3.sql from orders/line_items
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_line_items.sql from orders/line_items
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_refunds_ab1.sql from orders/refunds
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_refunds_ab2.sql from orders/refunds
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_refunds_ab3.sql from orders/refunds
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_refunds.sql from orders/refunds
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_fulfillments_ab1.sql from orders/fulfillments
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_fulfillments_ab2.sql from orders/fulfillments
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_fulfillments_ab3.sql from orders/fulfillments
2023-09-06 02:09:05 normalization >   Generating airbyte_incremental/public/orders_fulfillments.sql from orders/fulfillments
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_discounts_ab1.sql from orders/discounts
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_discounts_ab2.sql from orders/discounts
2023-09-06 02:09:05 normalization >   Generating airbyte_ctes/public/orders_discounts_ab3.sql from orders/discounts
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_discounts.sql from orders/discounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_ab1.sql from orders/tenders
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_ab2.sql from orders/tenders
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_ab3.sql from orders/tenders
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_tenders.sql from orders/tenders
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_total_discount_money_ab1.sql from orders/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_total_discount_money_ab2.sql from orders/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_total_discount_money_ab3.sql from orders/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_total_discount_money.sql from orders/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_ab1.sql from orders/net_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_ab2.sql from orders/net_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_ab3.sql from orders/net_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_net_amounts.sql from orders/net_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_ab1.sql from orders/return_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_ab2.sql from orders/return_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_ab3.sql from orders/return_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_return_amounts.sql from orders/return_amounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_ab1.sql from orders/returns
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_ab2.sql from orders/returns
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_ab3.sql from orders/returns
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns.sql from orders/returns
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_total_money_ab1.sql from orders/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_total_money_ab2.sql from orders/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_total_money_ab3.sql from orders/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_total_money.sql from orders/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_item_options_ab1.sql from items/item_data/item_options
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_item_options_ab2.sql from items/item_data/item_options
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_item_options_ab3.sql from items/item_data/item_options
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/items_item_data_item_options.sql from items/item_data/item_options
2023-09-06 02:09:06 normalization >   Ignoring stream 'tax_ids' from items/item_data/tax_ids because properties list is empty
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_variations_ab1.sql from items/item_data/variations
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_variations_ab2.sql from items/item_data/variations
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_variations_ab3.sql from items/item_data/variations
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/items_item_data_variations.sql from items/item_data/variations
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_modifier_list_info_ab1.sql from items/item_data/modifier_list_info
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_modifier_list_info_ab2.sql from items/item_data/modifier_list_info
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_modifier_list_info_ab3.sql from items/item_data/modifier_list_info
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/items_item_data_modifier_list_info.sql from items/item_data/modifier_list_info
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifier_list_data_modifiers_ab1.sql from modifier_list/modifier_list_data/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifier_list_data_modifiers_ab2.sql from modifier_list/modifier_list_data/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifier_list_data_modifiers_ab3.sql from modifier_list/modifier_list_data/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/modifier_list_modifier_list_data_modifiers.sql from modifier_list/modifier_list_data/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_applied_money_ab1.sql from orders/service_charges/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_applied_money_ab2.sql from orders/service_charges/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_applied_money_ab3.sql from orders/service_charges/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_service_charges_applied_money.sql from orders/service_charges/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_total_tax_money_ab1.sql from orders/service_charges/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_total_tax_money_ab2.sql from orders/service_charges/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_total_tax_money_ab3.sql from orders/service_charges/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_service_charges_total_tax_money.sql from orders/service_charges/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_amount_money_ab1.sql from orders/service_charges/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_amount_money_ab2.sql from orders/service_charges/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_amount_money_ab3.sql from orders/service_charges/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_service_charges_amount_money.sql from orders/service_charges/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_total_money_ab1.sql from orders/service_charges/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_total_money_ab2.sql from orders/service_charges/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_service_charges_total_money_ab3.sql from orders/service_charges/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_service_charges_total_money.sql from orders/service_charges/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_taxes_applied_money_ab1.sql from orders/taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_taxes_applied_money_ab2.sql from orders/taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_taxes_applied_money_ab3.sql from orders/taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_taxes_applied_money.sql from orders/taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_tax_money_ab1.sql from orders/line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_tax_money_ab2.sql from orders/line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_tax_money_ab3.sql from orders/line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_total_tax_money.sql from orders/line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_modifiers_ab1.sql from orders/line_items/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_modifiers_ab2.sql from orders/line_items/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_modifiers_ab3.sql from orders/line_items/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_modifiers.sql from orders/line_items/modifiers
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_gross_sales_money_ab1.sql from orders/line_items/gross_sales_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_gross_sales_money_ab2.sql from orders/line_items/gross_sales_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_gross_sales_money_ab3.sql from orders/line_items/gross_sales_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_gross_sales_money.sql from orders/line_items/gross_sales_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_va__ion_total_price_money_ab1.sql from orders/line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_va__ion_total_price_money_ab2.sql from orders/line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_va__ion_total_price_money_ab3.sql from orders/line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_va__ion_total_price_money.sql from orders/line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_base_price_money_ab1.sql from orders/line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_base_price_money_ab2.sql from orders/line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_base_price_money_ab3.sql from orders/line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_base_price_money.sql from orders/line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_discount_money_ab1.sql from orders/line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_discount_money_ab2.sql from orders/line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_discount_money_ab3.sql from orders/line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_total_discount_money.sql from orders/line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_money_ab1.sql from orders/line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_money_ab2.sql from orders/line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_total_money_ab3.sql from orders/line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_total_money.sql from orders/line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_applied_taxes_ab1.sql from orders/line_items/applied_taxes
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_applied_taxes_ab2.sql from orders/line_items/applied_taxes
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_applied_taxes_ab3.sql from orders/line_items/applied_taxes
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_applied_taxes.sql from orders/line_items/applied_taxes
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_applied_discounts_ab1.sql from orders/line_items/applied_discounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_applied_discounts_ab2.sql from orders/line_items/applied_discounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_applied_discounts_ab3.sql from orders/line_items/applied_discounts
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_applied_discounts.sql from orders/line_items/applied_discounts
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_refunds_amount_money_ab1.sql from orders/refunds/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_refunds_amount_money_ab2.sql from orders/refunds/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_refunds_amount_money_ab3.sql from orders/refunds/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_refunds_amount_money.sql from orders/refunds/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments_pickup_details_ab1.sql from orders/fulfillments/pickup_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments_pickup_details_ab2.sql from orders/fulfillments/pickup_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments_pickup_details_ab3.sql from orders/fulfillments/pickup_details
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_fulfillments_pickup_details.sql from orders/fulfillments/pickup_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments_shipment_details_ab1.sql from orders/fulfillments/shipment_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments_shipment_details_ab2.sql from orders/fulfillments/shipment_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments_shipment_details_ab3.sql from orders/fulfillments/shipment_details
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_fulfillments_shipment_details.sql from orders/fulfillments/shipment_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_discounts_applied_money_ab1.sql from orders/discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_discounts_applied_money_ab2.sql from orders/discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_discounts_applied_money_ab3.sql from orders/discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_discounts_applied_money.sql from orders/discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_card_details_ab1.sql from orders/tenders/card_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_card_details_ab2.sql from orders/tenders/card_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_card_details_ab3.sql from orders/tenders/card_details
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_tenders_card_details.sql from orders/tenders/card_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash_details_ab1.sql from orders/tenders/cash_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash_details_ab2.sql from orders/tenders/cash_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash_details_ab3.sql from orders/tenders/cash_details
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_tenders_cash_details.sql from orders/tenders/cash_details
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_amount_money_ab1.sql from orders/tenders/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_amount_money_ab2.sql from orders/tenders/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_amount_money_ab3.sql from orders/tenders/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_tenders_amount_money.sql from orders/tenders/amount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_discount_money_ab1.sql from orders/net_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_discount_money_ab2.sql from orders/net_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_discount_money_ab3.sql from orders/net_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_net_amounts_discount_money.sql from orders/net_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_tip_money_ab1.sql from orders/net_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_tip_money_ab2.sql from orders/net_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_tip_money_ab3.sql from orders/net_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_net_amounts_tip_money.sql from orders/net_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_total_money_ab1.sql from orders/net_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_total_money_ab2.sql from orders/net_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_total_money_ab3.sql from orders/net_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_net_amounts_total_money.sql from orders/net_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_service_charge_money_ab1.sql from orders/net_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_service_charge_money_ab2.sql from orders/net_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_service_charge_money_ab3.sql from orders/net_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_net_amounts_service_charge_money.sql from orders/net_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_tax_money_ab1.sql from orders/net_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_tax_money_ab2.sql from orders/net_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_net_amounts_tax_money_ab3.sql from orders/net_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_net_amounts_tax_money.sql from orders/net_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_discount_money_ab1.sql from orders/return_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_discount_money_ab2.sql from orders/return_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_discount_money_ab3.sql from orders/return_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_return_amounts_discount_money.sql from orders/return_amounts/discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_tip_money_ab1.sql from orders/return_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_tip_money_ab2.sql from orders/return_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_tip_money_ab3.sql from orders/return_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_return_amounts_tip_money.sql from orders/return_amounts/tip_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_total_money_ab1.sql from orders/return_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_total_money_ab2.sql from orders/return_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_total_money_ab3.sql from orders/return_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_return_amounts_total_money.sql from orders/return_amounts/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_service_charge_money_ab1.sql from orders/return_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_service_charge_money_ab2.sql from orders/return_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_service_charge_money_ab3.sql from orders/return_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_return_amounts_service_charge_money.sql from orders/return_amounts/service_charge_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_tax_money_ab1.sql from orders/return_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_tax_money_ab2.sql from orders/return_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_return_amounts_tax_money_ab3.sql from orders/return_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_return_amounts_tax_money.sql from orders/return_amounts/tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_return_line_items_ab1.sql from orders/returns/return_line_items
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_return_line_items_ab2.sql from orders/returns/return_line_items
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_return_line_items_ab3.sql from orders/returns/return_line_items
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns_return_line_items.sql from orders/returns/return_line_items
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__s_item_variation_data_ab1.sql from items/item_data/variations/item_variation_data
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__s_item_variation_data_ab2.sql from items/item_data/variations/item_variation_data
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__s_item_variation_data_ab3.sql from items/item_data/variations/item_variation_data
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/items_item_data_vari__s_item_variation_data.sql from items/item_data/variations/item_variation_data
2023-09-06 02:09:06 normalization >   Ignoring stream 'present_at_location_ids' from items/item_data/variations/present_at_location_ids because properties list is empty
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifi__difiers_modifier_data_ab1.sql from modifier_list/modifier_list_data/modifiers/modifier_data
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifi__difiers_modifier_data_ab2.sql from modifier_list/modifier_list_data/modifiers/modifier_data
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifi__difiers_modifier_data_ab3.sql from modifier_list/modifier_list_data/modifiers/modifier_data
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/modifier_list_modifi__difiers_modifier_data.sql from modifier_list/modifier_list_data/modifiers/modifier_data
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_mo__ers_total_price_money_ab1.sql from orders/line_items/modifiers/total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_mo__ers_total_price_money_ab2.sql from orders/line_items/modifiers/total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_mo__ers_total_price_money_ab3.sql from orders/line_items/modifiers/total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_mo__ers_total_price_money.sql from orders/line_items/modifiers/total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_mo__iers_base_price_money_ab1.sql from orders/line_items/modifiers/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_mo__iers_base_price_money_ab2.sql from orders/line_items/modifiers/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_mo__iers_base_price_money_ab3.sql from orders/line_items/modifiers/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_mo__iers_base_price_money.sql from orders/line_items/modifiers/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_ap__d_taxes_applied_money_ab1.sql from orders/line_items/applied_taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_ap__d_taxes_applied_money_ab2.sql from orders/line_items/applied_taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_ap__d_taxes_applied_money_ab3.sql from orders/line_items/applied_taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_ap__d_taxes_applied_money.sql from orders/line_items/applied_taxes/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_ap__scounts_applied_money_ab1.sql from orders/line_items/applied_discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_ap__scounts_applied_money_ab2.sql from orders/line_items/applied_discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_line_items_ap__scounts_applied_money_ab3.sql from orders/line_items/applied_discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_line_items_ap__scounts_applied_money.sql from orders/line_items/applied_discounts/applied_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___kup_details_recipient_ab1.sql from orders/fulfillments/pickup_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___kup_details_recipient_ab2.sql from orders/fulfillments/pickup_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___kup_details_recipient_ab3.sql from orders/fulfillments/pickup_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_fulfillments___kup_details_recipient.sql from orders/fulfillments/pickup_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___ent_details_recipient_ab1.sql from orders/fulfillments/shipment_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___ent_details_recipient_ab2.sql from orders/fulfillments/shipment_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___ent_details_recipient_ab3.sql from orders/fulfillments/shipment_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_fulfillments___ent_details_recipient.sql from orders/fulfillments/shipment_details/recipient
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_card_details_card_ab1.sql from orders/tenders/card_details/card
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_card_details_card_ab2.sql from orders/tenders/card_details/card
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_card_details_card_ab3.sql from orders/tenders/card_details/card
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_tenders_card_details_card.sql from orders/tenders/card_details/card
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash____buyer_tendered_money_ab1.sql from orders/tenders/cash_details/buyer_tendered_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash____buyer_tendered_money_ab2.sql from orders/tenders/cash_details/buyer_tendered_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash____buyer_tendered_money_ab3.sql from orders/tenders/cash_details/buyer_tendered_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_tenders_cash____buyer_tendered_money.sql from orders/tenders/cash_details/buyer_tendered_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash___ils_change_back_money_ab1.sql from orders/tenders/cash_details/change_back_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash___ils_change_back_money_ab2.sql from orders/tenders/cash_details/change_back_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_tenders_cash___ils_change_back_money_ab3.sql from orders/tenders/cash_details/change_back_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_tenders_cash___ils_change_back_money.sql from orders/tenders/cash_details/change_back_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__items_total_tax_money_ab1.sql from orders/returns/return_line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__items_total_tax_money_ab2.sql from orders/returns/return_line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__items_total_tax_money_ab3.sql from orders/returns/return_line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns_retur__items_total_tax_money.sql from orders/returns/return_line_items/total_tax_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ms_gross_return_money_ab1.sql from orders/returns/return_line_items/gross_return_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ms_gross_return_money_ab2.sql from orders/returns/return_line_items/gross_return_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ms_gross_return_money_ab3.sql from orders/returns/return_line_items/gross_return_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns_retur__ms_gross_return_money.sql from orders/returns/return_line_items/gross_return_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ion_total_price_money_ab1.sql from orders/returns/return_line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ion_total_price_money_ab2.sql from orders/returns/return_line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ion_total_price_money_ab3.sql from orders/returns/return_line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns_retur__ion_total_price_money.sql from orders/returns/return_line_items/variation_total_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__tems_base_price_money_ab1.sql from orders/returns/return_line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__tems_base_price_money_ab2.sql from orders/returns/return_line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__tems_base_price_money_ab3.sql from orders/returns/return_line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns_retur__tems_base_price_money.sql from orders/returns/return_line_items/base_price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur___total_discount_money_ab1.sql from orders/returns/return_line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur___total_discount_money_ab2.sql from orders/returns/return_line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur___total_discount_money_ab3.sql from orders/returns/return_line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns_retur___total_discount_money.sql from orders/returns/return_line_items/total_discount_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ine_items_total_money_ab1.sql from orders/returns/return_line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ine_items_total_money_ab2.sql from orders/returns/return_line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_returns_retur__ine_items_total_money_ab3.sql from orders/returns/return_line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_returns_retur__ine_items_total_money.sql from orders/returns/return_line_items/total_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__ta_item_option_values_ab1.sql from items/item_data/variations/item_variation_data/item_option_values
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__ta_item_option_values_ab2.sql from items/item_data/variations/item_variation_data/item_option_values
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__ta_item_option_values_ab3.sql from items/item_data/variations/item_variation_data/item_option_values
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/items_item_data_vari__ta_item_option_values.sql from items/item_data/variations/item_variation_data/item_option_values
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__tion_data_price_money_ab1.sql from items/item_data/variations/item_variation_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__tion_data_price_money_ab2.sql from items/item_data/variations/item_variation_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__tion_data_price_money_ab3.sql from items/item_data/variations/item_variation_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/items_item_data_vari__tion_data_price_money.sql from items/item_data/variations/item_variation_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__ta_location_overrides_ab1.sql from items/item_data/variations/item_variation_data/location_overrides
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__ta_location_overrides_ab2.sql from items/item_data/variations/item_variation_data/location_overrides
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/items_item_data_vari__ta_location_overrides_ab3.sql from items/item_data/variations/item_variation_data/location_overrides
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/items_item_data_vari__ta_location_overrides.sql from items/item_data/variations/item_variation_data/location_overrides
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifi__fier_data_price_money_ab1.sql from modifier_list/modifier_list_data/modifiers/modifier_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifi__fier_data_price_money_ab2.sql from modifier_list/modifier_list_data/modifiers/modifier_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/modifier_list_modifi__fier_data_price_money_ab3.sql from modifier_list/modifier_list_data/modifiers/modifier_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/modifier_list_modifi__fier_data_price_money.sql from modifier_list/modifier_list_data/modifiers/modifier_data/price_money
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___ils_recipient_address_ab1.sql from orders/fulfillments/shipment_details/recipient/address
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___ils_recipient_address_ab2.sql from orders/fulfillments/shipment_details/recipient/address
2023-09-06 02:09:06 normalization >   Generating airbyte_ctes/public/orders_fulfillments___ils_recipient_address_ab3.sql from orders/fulfillments/shipment_details/recipient/address
2023-09-06 02:09:06 normalization >   Generating airbyte_incremental/public/orders_fulfillments___ils_recipient_address.sql from orders/fulfillments/shipment_details/recipient/address
2023-09-06 02:09:06 normalization > detected no config file for ssh, assuming ssh is off.
2023-09-06 02:09:08 normalization >            [--event-buffer-size EVENT_BUFFER_SIZE]
2023-09-06 02:09:08 normalization >   --event-buffer-size EVENT_BUFFER_SIZE
2023-09-06 02:09:08 INFO i.a.w.n.NormalizationAirbyteStreamFactory(filterOutAndHandleNonAirbyteMessageLines):104 - 
2023-09-06 02:09:08 normalization > DBT >=1.0.0 detected; using 10K event buffer size
2023-09-06 02:09:08 INFO i.a.w.n.NormalizationAirbyteStreamFactory(filterOutAndHandleNonAirbyteMessageLines):104 - 
2023-09-06 02:09:10 normalization > Running with dbt=1.0.0
2023-09-06 02:09:10 normalization > Partial parse save file not found. Starting full parse.
2023-09-06 02:09:14 normalization > [WARNING]: Configuration paths exist in your dbt_project.yml file which do not apply to any resources.
There are 2 unused configuration paths:
- models.airbyte_utils.generated.airbyte_tables
- models.airbyte_utils.generated.airbyte_views

2023-09-06 02:09:14 normalization > Found 319 models, 0 tests, 0 snapshots, 0 analyses, 599 macros, 0 operations, 0 seed files, 3 sources, 0 exposures, 0 metrics
2023-09-06 02:09:19 normalization > Concurrency: 8 threads (target='prod')
2023-09-06 02:09:20 normalization > 1 of 85 START incremental model _airbyte_public.items_stg............................................................... [RUN]
2023-09-06 02:09:20 normalization > 2 of 85 START incremental model _airbyte_public.orders_stg.............................................................. [RUN]
2023-09-06 02:09:20 normalization > 3 of 85 START incremental model _airbyte_public.modifier_list_stg....................................................... [RUN]
2023-09-06 02:09:21 INFO i.a.n.SlackNotificationClient(notify):151 - Successful notification (200): {"message":"Workflow was started"}
2023-09-06 02:09:21 INFO i.a.v.j.JsonSchemaValidator(test):121 - JSON schema validation failed. 
errors: $.auth_type: must be a constant value OAuth, $.client_id: is missing but it is required, $.client_secret: is missing but it is required, $.refresh_token: is missing but it is required
2023-09-06 02:09:21 INFO i.a.v.j.JsonSchemaValidator(test):121 - JSON schema validation failed. 
errors: $.api_key: object found, string expected
2023-09-06 02:09:21 INFO i.a.c.t.StreamResetRecordsHelper(deleteStreamResetRecordsForJob):50 - deleteStreamResetRecordsForJob was called for job 124 with config type sync. Returning, as config type is not resetConnection.
2023-09-06 02:09:23 normalization > 2 of 85 OK created incremental model _airbyte_public.orders_stg......................................................... [INSERT 0 0 in 3.31s]
2023-09-06 02:09:23 normalization > 4 of 85 START incremental model public.orders_scd....................................................................... [RUN]
2023-09-06 02:09:23 normalization > 3 of 85 OK created incremental model _airbyte_public.modifier_list_stg.................................................. [INSERT 0 0 in 3.34s]
2023-09-06 02:09:23 normalization > 1 of 85 OK created incremental model _airbyte_public.items_stg.......................................................... [INSERT 0 1272 in 3.35s]
2023-09-06 02:09:23 normalization > 5 of 85 START incremental model public.modifier_list_scd................................................................ [RUN]
2023-09-06 02:09:23 normalization > 6 of 85 START incremental model public.items_scd........................................................................ [RUN]
2023-09-06 02:09:28 normalization > 6 of 85 OK created incremental model public.items_scd................................................................... [INSERT 0 2544 in 4.88s]
2023-09-06 02:09:28 normalization > 7 of 85 START incremental model public.items............................................................................ [RUN]
2023-09-06 02:09:28 normalization > 5 of 85 OK created incremental model public.modifier_list_scd........................................................... [INSERT 0 0 in 4.98s]
2023-09-06 02:09:28 normalization > 8 of 85 START incremental model public.modifier_list.................................................................... [RUN]
2023-09-06 02:09:28 normalization > 9 of 85 START incremental model public.items_item_data.................................................................. [RUN]
2023-09-06 02:09:28 normalization > 10 of 85 START incremental model public.modifier_list_modifier_list_data................................................ [RUN]
2023-09-06 02:09:28 normalization > 4 of 85 OK created incremental model public.orders_scd.................................................................. [INSERT 0 0 in 5.30s]
2023-09-06 02:09:28 normalization > 11 of 85 START incremental model public.orders.......................................................................... [RUN]
2023-09-06 02:09:30 normalization > 12 of 85 START incremental model public.orders_discounts................................................................ [RUN]
2023-09-06 02:09:30 normalization > 13 of 85 START incremental model public.orders_fulfillments............................................................. [RUN]
2023-09-06 02:09:30 normalization > 14 of 85 START incremental model public.orders_line_items............................................................... [RUN]
2023-09-06 02:09:31 normalization > 8 of 85 OK created incremental model public.modifier_list............................................................... [INSERT 0 0 in 3.20s]
2023-09-06 02:09:31 normalization > 15 of 85 START incremental model public.orders_net_amounts.............................................................. [RUN]
2023-09-06 02:09:31 normalization > 7 of 85 OK created incremental model public.items....................................................................... [INSERT 0 1272 in 3.36s]
2023-09-06 02:09:31 normalization > 16 of 85 START incremental model public.orders_refunds.................................................................. [RUN]
2023-09-06 02:09:31 normalization > 10 of 85 OK created incremental model public.modifier_list_modifier_list_data........................................... [INSERT 0 0 in 3.31s]
2023-09-06 02:09:31 normalization > 17 of 85 START incremental model public.orders_return_amounts........................................................... [RUN]
2023-09-06 02:09:32 normalization > 11 of 85 OK created incremental model public.orders..................................................................... [INSERT 0 0 in 3.33s]
2023-09-06 02:09:32 normalization > 18 of 85 START incremental model public.orders_returns.................................................................. [RUN]
2023-09-06 02:09:32 normalization > 9 of 85 OK created incremental model public.items_item_data............................................................. [INSERT 0 1272 in 3.60s]
2023-09-06 02:09:32 normalization > 19 of 85 START incremental model public.orders_service_charges.......................................................... [RUN]
2023-09-06 02:09:33 normalization > 12 of 85 OK created incremental model public.orders_discounts........................................................... [INSERT 0 0 in 3.29s]
2023-09-06 02:09:33 normalization > 20 of 85 START incremental model public.orders_source................................................................... [RUN]
2023-09-06 02:09:33 normalization > 13 of 85 OK created incremental model public.orders_fulfillments........................................................ [INSERT 0 0 in 3.24s]
2023-09-06 02:09:33 normalization > 14 of 85 OK created incremental model public.orders_line_items.......................................................... [INSERT 0 0 in 3.25s]
2023-09-06 02:09:33 normalization > 21 of 85 START incremental model public.orders_total_discount_money..................................................... [RUN]
2023-09-06 02:09:33 normalization > 22 of 85 START incremental model public.orders_taxes.................................................................... [RUN]
2023-09-06 02:09:34 normalization > 15 of 85 OK created incremental model public.orders_net_amounts......................................................... [INSERT 0 0 in 3.19s]
2023-09-06 02:09:34 normalization > 23 of 85 START incremental model public.orders_tenders.................................................................. [RUN]
2023-09-06 02:09:34 normalization > 16 of 85 OK created incremental model public.orders_refunds............................................................. [INSERT 0 0 in 3.19s]
2023-09-06 02:09:34 normalization > 24 of 85 START incremental model public.orders_total_service_charge_money............................................... [RUN]
2023-09-06 02:09:35 normalization > 19 of 85 OK created incremental model public.orders_service_charges..................................................... [INSERT 0 0 in 2.96s]
2023-09-06 02:09:35 normalization > 18 of 85 OK created incremental model public.orders_returns............................................................. [INSERT 0 0 in 3.15s]
2023-09-06 02:09:35 normalization > 25 of 85 START incremental model public.orders_total_money.............................................................. [RUN]
2023-09-06 02:09:35 normalization > 26 of 85 START incremental model public.orders_total_tax_money.......................................................... [RUN]
2023-09-06 02:09:35 normalization > 17 of 85 OK created incremental model public.orders_return_amounts...................................................... [INSERT 0 0 in 3.26s]
2023-09-06 02:09:35 normalization > 27 of 85 START incremental model public.orders_total_tip_money.......................................................... [RUN]
2023-09-06 02:09:36 normalization > 22 of 85 OK created incremental model public.orders_taxes............................................................... [INSERT 0 0 in 3.16s]
2023-09-06 02:09:37 normalization > 20 of 85 OK created incremental model public.orders_source.............................................................. [INSERT 0 0 in 3.36s]
2023-09-06 02:09:37 normalization > 21 of 85 OK created incremental model public.orders_total_discount_money................................................ [INSERT 0 0 in 3.28s]
2023-09-06 02:09:38 normalization > 24 of 85 OK created incremental model public.orders_total_service_charge_money.......................................... [INSERT 0 0 in 3.19s]
2023-09-06 02:09:38 normalization > 23 of 85 OK created incremental model public.orders_tenders............................................................. [INSERT 0 0 in 3.26s]
2023-09-06 02:09:38 normalization > 25 of 85 OK created incremental model public.orders_total_money......................................................... [INSERT 0 0 in 3.28s]
2023-09-06 02:09:38 normalization > 26 of 85 OK created incremental model public.orders_total_tax_money..................................................... [INSERT 0 0 in 3.43s]
2023-09-06 02:09:38 normalization > 27 of 85 OK created incremental model public.orders_total_tip_money..................................................... [INSERT 0 0 in 3.38s]
2023-09-06 02:09:39 normalization > 28 of 85 START incremental model public.modifier_list_modifier_list_data_modifiers...................................... [RUN]
2023-09-06 02:09:39 normalization > 29 of 85 START incremental model public.items_item_data_item_options.................................................... [RUN]
2023-09-06 02:09:39 normalization > 30 of 85 START incremental model public.items_item_data_modifier_list_info.............................................. [RUN]
2023-09-06 02:09:39 normalization > 31 of 85 START incremental model public.items_item_data_variations...................................................... [RUN]
2023-09-06 02:09:39 normalization > 32 of 85 START incremental model public.orders_discounts_applied_money.................................................. [RUN]
2023-09-06 02:09:39 normalization > 33 of 85 START incremental model public.orders_fulfillments_pickup_details.............................................. [RUN]
2023-09-06 02:09:39 normalization > 34 of 85 START incremental model public.orders_fulfillments_shipment_details............................................ [RUN]
2023-09-06 02:09:39 normalization > 35 of 85 START incremental model public.orders_line_items_applied_discounts............................................. [RUN]
2023-09-06 02:09:42 normalization > 28 of 85 OK created incremental model public.modifier_list_modifier_list_data_modifiers................................. [INSERT 0 0 in 3.14s]
2023-09-06 02:09:42 normalization > 36 of 85 START incremental model public.orders_line_items_applied_taxes................................................. [RUN]
2023-09-06 02:09:43 normalization > 31 of 85 OK created incremental model public.items_item_data_variations................................................. [INSERT 0 337 in 3.15s]
2023-09-06 02:09:43 normalization > 37 of 85 START incremental model public.orders_line_items_base_price_money.............................................. [RUN]
2023-09-06 02:09:43 normalization > 33 of 85 OK created incremental model public.orders_fulfillments_pickup_details......................................... [INSERT 0 0 in 3.30s]
2023-09-06 02:09:43 normalization > 38 of 85 START incremental model public.orders_line_items_gross_sales_money............................................. [RUN]
2023-09-06 02:09:43 normalization > 35 of 85 OK created incremental model public.orders_line_items_applied_discounts........................................ [INSERT 0 0 in 3.33s]
2023-09-06 02:09:43 normalization > 39 of 85 START incremental model public.orders_line_items_modifiers..................................................... [RUN]
2023-09-06 02:09:43 normalization > 34 of 85 OK created incremental model public.orders_fulfillments_shipment_details....................................... [INSERT 0 0 in 3.36s]
2023-09-06 02:09:43 normalization > 32 of 85 OK created incremental model public.orders_discounts_applied_money............................................. [INSERT 0 0 in 3.38s]
2023-09-06 02:09:43 normalization > 40 of 85 START incremental model public.orders_line_items_total_discount_money.......................................... [RUN]
2023-09-06 02:09:43 normalization > 41 of 85 START incremental model public.orders_line_items_total_money................................................... [RUN]
2023-09-06 02:09:43 normalization > 30 of 85 OK created incremental model public.items_item_data_modifier_list_info......................................... [INSERT 0 23 in 3.55s]
2023-09-06 02:09:43 normalization > 42 of 85 START incremental model public.orders_line_items_total_tax_money............................................... [RUN]
2023-09-06 02:09:43 normalization > 29 of 85 OK created incremental model public.items_item_data_item_options............................................... [INSERT 0 1 in 3.61s]
2023-09-06 02:09:43 normalization > 43 of 85 START incremental model public.orders_line_items_va__ion_total_price_money..................................... [RUN]
2023-09-06 02:09:46 normalization > 36 of 85 OK created incremental model public.orders_line_items_applied_taxes............................................ [INSERT 0 0 in 3.14s]
2023-09-06 02:09:46 normalization > 44 of 85 START incremental model public.orders_net_amounts_discount_money............................................... [RUN]
2023-09-06 02:09:46 normalization > 37 of 85 OK created incremental model public.orders_line_items_base_price_money......................................... [INSERT 0 0 in 3.05s]
2023-09-06 02:09:46 normalization > 45 of 85 START incremental model public.orders_net_amounts_service_charge_money......................................... [RUN]
2023-09-06 02:09:46 normalization > 39 of 85 OK created incremental model public.orders_line_items_modifiers................................................ [INSERT 0 0 in 3.12s]
2023-09-06 02:09:46 normalization > 46 of 85 START incremental model public.orders_net_amounts_tax_money.................................................... [RUN]
2023-09-06 02:09:46 normalization > 40 of 85 OK created incremental model public.orders_line_items_total_discount_money..................................... [INSERT 0 0 in 3.12s]
2023-09-06 02:09:46 normalization > 41 of 85 OK created incremental model public.orders_line_items_total_money.............................................. [INSERT 0 0 in 3.12s]
2023-09-06 02:09:46 normalization > 47 of 85 START incremental model public.orders_net_amounts_tip_money.................................................... [RUN]
2023-09-06 02:09:46 normalization > 48 of 85 START incremental model public.orders_net_amounts_total_money.................................................. [RUN]
2023-09-06 02:09:46 normalization > 43 of 85 OK created incremental model public.orders_line_items_va__ion_total_price_money................................ [INSERT 0 0 in 3.00s]
2023-09-06 02:09:46 normalization > 49 of 85 START incremental model public.orders_refunds_amount_money..................................................... [RUN]
2023-09-06 02:09:46 normalization > 42 of 85 OK created incremental model public.orders_line_items_total_tax_money.......................................... [INSERT 0 0 in 3.14s]
2023-09-06 02:09:46 normalization > 50 of 85 START incremental model public.orders_service_charges_amount_money............................................. [RUN]
2023-09-06 02:09:46 normalization > 38 of 85 OK created incremental model public.orders_line_items_gross_sales_money........................................ [INSERT 0 0 in 3.40s]
2023-09-06 02:09:46 normalization > 51 of 85 START incremental model public.orders_service_charges_applied_money............................................ [RUN]
2023-09-06 02:09:49 normalization > 45 of 85 OK created incremental model public.orders_net_amounts_service_charge_money.................................... [INSERT 0 0 in 2.96s]
2023-09-06 02:09:49 normalization > 44 of 85 OK created incremental model public.orders_net_amounts_discount_money.......................................... [INSERT 0 0 in 3.09s]
2023-09-06 02:09:49 normalization > 52 of 85 START incremental model public.orders_service_charges_total_money.............................................. [RUN]
2023-09-06 02:09:49 normalization > 53 of 85 START incremental model public.orders_service_charges_total_tax_money.......................................... [RUN]
2023-09-06 02:09:49 normalization > 46 of 85 OK created incremental model public.orders_net_amounts_tax_money............................................... [INSERT 0 0 in 2.97s]
2023-09-06 02:09:49 normalization > 54 of 85 START incremental model public.orders_returns_return_line_items................................................ [RUN]
2023-09-06 02:09:49 normalization > 48 of 85 OK created incremental model public.orders_net_amounts_total_money............................................. [INSERT 0 0 in 3.02s]
2023-09-06 02:09:49 normalization > 55 of 85 START incremental model public.orders_return_amounts_discount_money............................................ [RUN]
2023-09-06 02:09:49 normalization > 49 of 85 OK created incremental model public.orders_refunds_amount_money................................................ [INSERT 0 0 in 3.00s]
2023-09-06 02:09:49 normalization > 56 of 85 START incremental model public.orders_return_amounts_service_charge_money...................................... [RUN]
2023-09-06 02:09:49 normalization > 50 of 85 OK created incremental model public.orders_service_charges_amount_money........................................ [INSERT 0 0 in 3.06s]
2023-09-06 02:09:49 normalization > 57 of 85 START incremental model public.orders_return_amounts_tax_money................................................. [RUN]
2023-09-06 02:09:49 normalization > 47 of 85 OK created incremental model public.orders_net_amounts_tip_money............................................... [INSERT 0 0 in 3.26s]
2023-09-06 02:09:49 normalization > 58 of 85 START incremental model public.orders_return_amounts_tip_money................................................. [RUN]
2023-09-06 02:09:49 normalization > 51 of 85 OK created incremental model public.orders_service_charges_applied_money....................................... [INSERT 0 0 in 3.27s]
2023-09-06 02:09:49 normalization > 59 of 85 START incremental model public.orders_return_amounts_total_money............................................... [RUN]
2023-09-06 02:09:52 normalization > 52 of 85 OK created incremental model public.orders_service_charges_total_money......................................... [INSERT 0 0 in 2.94s]
2023-09-06 02:09:52 normalization > 60 of 85 START incremental model public.orders_taxes_applied_money...................................................... [RUN]
2023-09-06 02:09:52 normalization > 54 of 85 OK created incremental model public.orders_returns_return_line_items........................................... [INSERT 0 0 in 2.94s]
2023-09-06 02:09:52 normalization > 53 of 85 OK created incremental model public.orders_service_charges_total_tax_money..................................... [INSERT 0 0 in 3.23s]
2023-09-06 02:09:52 normalization > 56 of 85 OK created incremental model public.orders_return_amounts_service_charge_money................................. [INSERT 0 0 in 3.29s]
2023-09-06 02:09:52 normalization > 55 of 85 OK created incremental model public.orders_return_amounts_discount_money....................................... [INSERT 0 0 in 3.32s]
2023-09-06 02:09:52 normalization > 61 of 85 START incremental model public.orders_tenders_amount_money..................................................... [RUN]
2023-09-06 02:09:52 normalization > 62 of 85 START incremental model public.orders_tenders_card_details..................................................... [RUN]
2023-09-06 02:09:52 normalization > 63 of 85 START incremental model public.orders_tenders_cash_details..................................................... [RUN]
2023-09-06 02:09:52 normalization > 57 of 85 OK created incremental model public.orders_return_amounts_tax_money............................................ [INSERT 0 0 in 3.23s]
2023-09-06 02:09:52 normalization > 58 of 85 OK created incremental model public.orders_return_amounts_tip_money............................................ [INSERT 0 0 in 3.20s]
2023-09-06 02:09:52 normalization > 59 of 85 OK created incremental model public.orders_return_amounts_total_money.......................................... [INSERT 0 0 in 3.07s]
2023-09-06 02:09:53 normalization > 64 of 85 START incremental model public.modifier_list_modifi__difiers_modifier_data..................................... [RUN]
2023-09-06 02:09:53 normalization > 65 of 85 START incremental model public.items_item_data_vari__s_item_variation_data..................................... [RUN]
2023-09-06 02:09:53 normalization > 66 of 85 START incremental model public.orders_fulfillments___kup_details_recipient..................................... [RUN]
2023-09-06 02:09:53 normalization > 67 of 85 START incremental model public.orders_line_items_ap__scounts_applied_money..................................... [RUN]
2023-09-06 02:09:55 normalization > 60 of 85 OK created incremental model public.orders_taxes_applied_money................................................. [INSERT 0 0 in 3.13s]
2023-09-06 02:09:55 normalization > 68 of 85 START incremental model public.orders_fulfillments___ent_details_recipient..................................... [RUN]
2023-09-06 02:09:55 normalization > 61 of 85 OK created incremental model public.orders_tenders_amount_money................................................ [INSERT 0 0 in 3.01s]
2023-09-06 02:09:55 normalization > 69 of 85 START incremental model public.orders_line_items_mo__ers_total_price_money..................................... [RUN]
2023-09-06 02:09:56 normalization > 63 of 85 OK created incremental model public.orders_tenders_cash_details................................................ [INSERT 0 0 in 3.31s]
2023-09-06 02:09:56 normalization > 62 of 85 OK created incremental model public.orders_tenders_card_details................................................ [INSERT 0 0 in 3.31s]
2023-09-06 02:09:56 normalization > 70 of 85 START incremental model public.orders_line_items_ap__d_taxes_applied_money..................................... [RUN]
2023-09-06 02:09:56 normalization > 71 of 85 START incremental model public.orders_line_items_mo__iers_base_price_money..................................... [RUN]
2023-09-06 02:09:56 normalization > 65 of 85 OK created incremental model public.items_item_data_vari__s_item_variation_data................................ [INSERT 0 337 in 3.20s]
2023-09-06 02:09:56 normalization > 72 of 85 START incremental model public.orders_returns_retur___total_discount_money..................................... [RUN]
2023-09-06 02:09:56 normalization > 64 of 85 OK created incremental model public.modifier_list_modifi__difiers_modifier_data................................ [INSERT 0 0 in 3.30s]
2023-09-06 02:09:56 normalization > 73 of 85 START incremental model public.orders_returns_retur__ine_items_total_money..................................... [RUN]
2023-09-06 02:09:56 normalization > 66 of 85 OK created incremental model public.orders_fulfillments___kup_details_recipient................................ [INSERT 0 0 in 3.26s]
2023-09-06 02:09:56 normalization > 67 of 85 OK created incremental model public.orders_line_items_ap__scounts_applied_money................................ [INSERT 0 0 in 3.23s]
2023-09-06 02:09:56 normalization > 74 of 85 START incremental model public.orders_returns_retur__ion_total_price_money..................................... [RUN]
2023-09-06 02:09:56 normalization > 75 of 85 START incremental model public.orders_returns_retur__items_total_tax_money..................................... [RUN]
2023-09-06 02:09:58 normalization > 68 of 85 OK created incremental model public.orders_fulfillments___ent_details_recipient................................ [INSERT 0 0 in 2.94s]
2023-09-06 02:09:58 normalization > 76 of 85 START incremental model public.orders_returns_retur__ms_gross_return_money..................................... [RUN]
2023-09-06 02:09:58 normalization > 69 of 85 OK created incremental model public.orders_line_items_mo__ers_total_price_money................................ [INSERT 0 0 in 2.97s]
2023-09-06 02:09:58 normalization > 77 of 85 START incremental model public.orders_returns_retur__tems_base_price_money..................................... [RUN]
2023-09-06 02:09:59 normalization > 71 of 85 OK created incremental model public.orders_line_items_mo__iers_base_price_money................................ [INSERT 0 0 in 2.98s]
2023-09-06 02:09:59 normalization > 70 of 85 OK created incremental model public.orders_line_items_ap__d_taxes_applied_money................................ [INSERT 0 0 in 3.18s]
2023-09-06 02:09:59 normalization > 78 of 85 START incremental model public.orders_tenders_cash____buyer_tendered_money..................................... [RUN]
2023-09-06 02:09:59 normalization > 79 of 85 START incremental model public.orders_tenders_cash___ils_change_back_money..................................... [RUN]
2023-09-06 02:10:00 normalization > 75 of 85 OK created incremental model public.orders_returns_retur__items_total_tax_money................................ [INSERT 0 0 in 3.12s]
2023-09-06 02:10:00 normalization > 80 of 85 START incremental model public.orders_tenders_card_details_card................................................ [RUN]
2023-09-06 02:10:00 normalization > 74 of 85 OK created incremental model public.orders_returns_retur__ion_total_price_money................................ [INSERT 0 0 in 3.14s]
2023-09-06 02:10:00 normalization > 81 of 85 START incremental model public.items_item_data_vari__ta_item_option_values..................................... [RUN]
2023-09-06 02:10:00 normalization > 73 of 85 OK created incremental model public.orders_returns_retur__ine_items_total_money................................ [INSERT 0 0 in 3.20s]
2023-09-06 02:10:00 normalization > 72 of 85 OK created incremental model public.orders_returns_retur___total_discount_money................................ [INSERT 0 0 in 3.30s]
2023-09-06 02:10:00 normalization > 82 of 85 START incremental model public.items_item_data_vari__ta_location_overrides..................................... [RUN]
2023-09-06 02:10:00 normalization > 83 of 85 START incremental model public.items_item_data_vari__tion_data_price_money..................................... [RUN]
2023-09-06 02:10:01 normalization > 76 of 85 OK created incremental model public.orders_returns_retur__ms_gross_return_money................................ [INSERT 0 0 in 3.12s]
2023-09-06 02:10:01 normalization > 84 of 85 START incremental model public.modifier_list_modifi__fier_data_price_money..................................... [RUN]
2023-09-06 02:10:01 normalization > 77 of 85 OK created incremental model public.orders_returns_retur__tems_base_price_money................................ [INSERT 0 0 in 2.89s]
2023-09-06 02:10:01 normalization > 85 of 85 START incremental model public.orders_fulfillments___ils_recipient_address..................................... [RUN]
2023-09-06 02:10:02 normalization > 78 of 85 OK created incremental model public.orders_tenders_cash____buyer_tendered_money................................ [INSERT 0 0 in 2.95s]
2023-09-06 02:10:02 normalization > 79 of 85 OK created incremental model public.orders_tenders_cash___ils_change_back_money................................ [INSERT 0 0 in 3.22s]
2023-09-06 02:10:02 normalization > 80 of 85 OK created incremental model public.orders_tenders_card_details_card........................................... [INSERT 0 0 in 2.86s]
2023-09-06 02:10:03 normalization > 82 of 85 OK created incremental model public.items_item_data_vari__ta_location_overrides................................ [INSERT 0 1384 in 2.92s]
2023-09-06 02:10:03 normalization > 83 of 85 OK created incremental model public.items_item_data_vari__tion_data_price_money................................ [INSERT 0 337 in 2.95s]
2023-09-06 02:10:03 normalization > 81 of 85 OK created incremental model public.items_item_data_vari__ta_item_option_values................................ [INSERT 0 3 in 3.02s]
2023-09-06 02:10:04 normalization > 84 of 85 OK created incremental model public.modifier_list_modifi__fier_data_price_money................................ [INSERT 0 0 in 3.06s]
2023-09-06 02:10:04 normalization > 85 of 85 OK created incremental model public.orders_fulfillments___ils_recipient_address................................ [INSERT 0 0 in 3.07s]
2023-09-06 02:10:06 normalization > Finished running 85 incremental models in 51.37s.
2023-09-06 02:10:06 normalization > Completed successfully
2023-09-06 02:10:06 normalization > Done. PASS=85 WARN=0 ERROR=0 SKIP=0 TOTAL=85
2023-09-06 02:10:06 INFO i.a.w.n.DefaultNormalizationRunner(close):196 - Terminating normalization process...
2023-09-06 02:10:06 INFO i.a.w.n.DefaultNormalizationRunner(close):209 - Normalization process successfully terminated.
2023-09-06 02:10:06 INFO i.a.w.g.DefaultNormalizationWorker(run):97 - Normalization executed in 1 minute 1 second for job 125.
2023-09-06 02:10:06 INFO i.a.w.g.DefaultNormalizationWorker(run):109 - Normalization summary: io.airbyte.config.NormalizationSummary@91bc895[startTime=1693966144598,endTime=1693966206516,failures=[],additionalProperties={}]
2023-09-06 02:10:06 INFO i.a.w.t.TemporalAttemptExecution(get):163 - Stopping cancellation check scheduling...
2023-09-06 02:10:06 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:06 INFO i.a.c.t.TemporalUtils(withBackgroundHeartbeat):307 - Stopping temporal heartbeating...
2023-09-06 02:10:06 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- END DEFAULT NORMALIZATION -----
2023-09-06 02:10:06 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:13 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to Get a connection by connection Id
2023-09-06 02:10:13 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to get the most recent source actor catalog
2023-09-06 02:10:13 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to Get a connection by connection Id
2023-09-06 02:10:06 INFO i.a.w.t.TemporalAttemptExecution(get):136 - Docker volume job log path: /tmp/workspace/125/2/logs.log
2023-09-06 02:10:06 INFO i.a.w.t.TemporalAttemptExecution(get):141 - Executing worker wrapper. Airbyte version: 0.44.5
2023-09-06 02:10:06 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to save workflow id for cancellation
2023-09-06 02:10:06 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:06 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:06 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- START CHECK -----
2023-09-06 02:10:06 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:06 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:06 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:06 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:06 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable LAUNCHDARKLY_KEY: ''
2023-09-06 02:10:06 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable FEATURE_FLAG_CLIENT: ''
2023-09-06 02:10:06 INFO i.a.c.i.LineGobbler(voidCall):149 - Checking if airbyte/source-square:1.1.2 exists...
2023-09-06 02:10:07 INFO i.a.c.i.LineGobbler(voidCall):149 - airbyte/source-square:1.1.2 was found locally.
2023-09-06 02:10:07 INFO i.a.w.p.DockerProcessFactory(create):139 - Creating docker container = source-square-check-125-2-wrguq with resources io.airbyte.config.ResourceRequirements@25f93e0d[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=,additionalProperties={}] and allowedHosts null
2023-09-06 02:10:07 INFO i.a.w.p.DockerProcessFactory(create):192 - Preparing command: docker run --rm --init -i -w /data/125/2 --log-driver none --name source-square-check-125-2-wrguq --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e WORKER_CONNECTOR_IMAGE=airbyte/source-square:1.1.2 -e AUTO_DETECT_SCHEMA=true -e LAUNCHDARKLY_KEY= -e SOCAT_KUBE_CPU_REQUEST=0.1 -e SOCAT_KUBE_CPU_LIMIT=2.0 -e USE_STREAM_CAPABLE_STATE=true -e FIELD_SELECTION_WORKSPACES= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_ROLE= -e APPLY_FIELD_SELECTION=false -e WORKER_JOB_ATTEMPT=2 -e OTEL_COLLECTOR_ENDPOINT=http://host.docker.internal:4317 -e FEATURE_FLAG_CLIENT= -e AIRBYTE_VERSION=0.44.5 -e WORKER_JOB_ID=125 airbyte/source-square:1.1.2 check --config source_config.json
2023-09-06 02:10:07 INFO i.a.w.i.VersionedAirbyteStreamFactory(create):181 - Reading messages from protocol version 0.2.0
2023-09-06 02:10:08 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - Check succeeded
2023-09-06 02:10:08 INFO i.a.w.g.DefaultCheckConnectionWorker(run):115 - Check connection job received output: io.airbyte.config.StandardCheckConnectionOutput@440c4016[status=succeeded,message=<null>,additionalProperties={}]
2023-09-06 02:10:08 INFO i.a.w.t.TemporalAttemptExecution(get):163 - Stopping cancellation check scheduling...
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- END CHECK -----
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:08 INFO i.a.w.t.TemporalAttemptExecution(get):136 - Docker volume job log path: /tmp/workspace/125/2/logs.log
2023-09-06 02:10:08 INFO i.a.w.t.TemporalAttemptExecution(get):141 - Executing worker wrapper. Airbyte version: 0.44.5
2023-09-06 02:10:08 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to save workflow id for cancellation
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:08 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- START CHECK -----
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:08 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:08 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:08 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:08 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable LAUNCHDARKLY_KEY: ''
2023-09-06 02:10:08 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable FEATURE_FLAG_CLIENT: ''
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - Checking if airbyte/destination-postgres:0.3.27 exists...
2023-09-06 02:10:08 INFO i.a.c.i.LineGobbler(voidCall):149 - airbyte/destination-postgres:0.3.27 was found locally.
2023-09-06 02:10:08 INFO i.a.w.p.DockerProcessFactory(create):139 - Creating docker container = destination-postgres-check-125-2-ofmyj with resources io.airbyte.config.ResourceRequirements@44d2a741[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=,additionalProperties={}] and allowedHosts null
2023-09-06 02:10:08 INFO i.a.w.p.DockerProcessFactory(create):192 - Preparing command: docker run --rm --init -i -w /data/125/2 --log-driver none --name destination-postgres-check-125-2-ofmyj --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e WORKER_CONNECTOR_IMAGE=airbyte/destination-postgres:0.3.27 -e AUTO_DETECT_SCHEMA=true -e LAUNCHDARKLY_KEY= -e SOCAT_KUBE_CPU_REQUEST=0.1 -e SOCAT_KUBE_CPU_LIMIT=2.0 -e USE_STREAM_CAPABLE_STATE=true -e FIELD_SELECTION_WORKSPACES= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_ROLE= -e APPLY_FIELD_SELECTION=false -e WORKER_JOB_ATTEMPT=2 -e OTEL_COLLECTOR_ENDPOINT=http://host.docker.internal:4317 -e FEATURE_FLAG_CLIENT= -e AIRBYTE_VERSION=0.44.5 -e WORKER_JOB_ID=125 airbyte/destination-postgres:0.3.27 check --config source_config.json
2023-09-06 02:10:08 INFO i.a.w.i.VersionedAirbyteStreamFactory(create):181 - Reading messages from protocol version 0.2.0
2023-09-06 02:10:09 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.d.p.PostgresDestination(main):98 starting destination: class io.airbyte.integrations.destination.postgres.PostgresDestination
2023-09-06 02:10:09 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.b.IntegrationCliParser(parseOptions):126 integration args: {check=null, config=source_config.json}
2023-09-06 02:10:09 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.b.IntegrationRunner(runInternal):108 Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination
2023-09-06 02:10:09 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.b.IntegrationRunner(runInternal):109 Command: CHECK
2023-09-06 02:10:09 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.b.IntegrationRunner(runInternal):110 Integration config: IntegrationConfig{command=CHECK, configPath='source_config.json', catalogPath='null', statePath='null'}
2023-09-06 02:10:09 WARN i.a.w.i.VersionedAirbyteStreamFactory(internalLog):314 - WARN c.n.s.JsonMetaSchema(newValidator):278 Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword
2023-09-06 02:10:09 WARN i.a.w.i.VersionedAirbyteStreamFactory(internalLog):314 - WARN c.n.s.JsonMetaSchema(newValidator):278 Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword
2023-09-06 02:10:09 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.b.s.SshTunnel(getInstance):204 Starting connection with method: NO_TUNNEL
2023-09-06 02:10:10 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO c.z.h.HikariDataSource(<init>):80 HikariPool-1 - Starting...
2023-09-06 02:10:10 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO c.z.h.HikariDataSource(<init>):82 HikariPool-1 - Start completed.
2023-09-06 02:10:12 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO c.z.h.HikariDataSource(close):350 HikariPool-1 - Shutdown initiated...
2023-09-06 02:10:12 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO c.z.h.HikariDataSource(close):352 HikariPool-1 - Shutdown completed.
2023-09-06 02:10:12 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.b.IntegrationRunner(runInternal):186 Completed integration: io.airbyte.integrations.base.ssh.SshWrappedDestination
2023-09-06 02:10:12 INFO i.a.w.i.VersionedAirbyteStreamFactory(internalLog):317 - INFO i.a.i.d.p.PostgresDestination(main):100 completed destination: class io.airbyte.integrations.destination.postgres.PostgresDestination
2023-09-06 02:10:12 INFO i.a.w.g.DefaultCheckConnectionWorker(run):115 - Check connection job received output: io.airbyte.config.StandardCheckConnectionOutput@339911e8[status=succeeded,message=<null>,additionalProperties={}]
2023-09-06 02:10:12 INFO i.a.w.t.TemporalAttemptExecution(get):163 - Stopping cancellation check scheduling...
2023-09-06 02:10:12 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:12 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- END CHECK -----
2023-09-06 02:10:12 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:12 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to get state
2023-09-06 02:10:12 INFO i.a.w.h.NormalizationInDestinationHelper(shouldNormalizeInDestination):52 - Requires Normalization: true Normalization Supported: false, Feature Flag Enabled: false
2023-09-06 02:10:12 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to set attempt sync config
2023-09-06 02:10:12 INFO i.a.c.t.s.DefaultTaskQueueMapper(getTaskQueue):31 - Called DefaultTaskQueueMapper getTaskQueue for geography auto
2023-09-06 02:10:13 INFO i.a.w.t.TemporalAttemptExecution(get):136 - Docker volume job log path: /tmp/workspace/125/2/logs.log
2023-09-06 02:10:13 INFO i.a.w.t.TemporalAttemptExecution(get):141 - Executing worker wrapper. Airbyte version: 0.44.5
2023-09-06 02:10:13 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to save workflow id for cancellation
2023-09-06 02:10:13 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to get the source for heartbeat
2023-09-06 02:10:13 INFO i.a.a.c.AirbyteApiClient(retryWithJitterThrows):222 - Attempt 0 to get the source definition
2023-09-06 02:10:13 INFO i.a.w.g.ReplicationWorkerFactory(create):96 - Setting up source...
2023-09-06 02:10:13 INFO i.a.w.g.ReplicationWorkerFactory(create):100 - Setting up destination...
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable METRIC_CLIENT: ''
2023-09-06 02:10:13 WARN i.a.m.l.MetricClientFactory(initialize):60 - Metric client is already initialized to 
2023-09-06 02:10:13 INFO i.a.w.g.ReplicationWorkerFactory(create):109 - Setting up replication worker...
2023-09-06 02:10:13 INFO i.a.w.g.DefaultReplicationWorker(run):147 - start sync worker. job id: 125 attempt id: 2
2023-09-06 02:10:13 INFO i.a.w.g.DefaultReplicationWorker(run):149 - Committing states from replication activity
2023-09-06 02:10:13 INFO i.a.w.g.DefaultReplicationWorker(run):152 - Committing stats from replication activity
2023-09-06 02:10:13 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:13 INFO i.a.c.i.LineGobbler(voidCall):149 - ----- START REPLICATION -----
2023-09-06 02:10:13 INFO i.a.c.i.LineGobbler(voidCall):149 - 
2023-09-06 02:10:13 INFO i.a.w.g.DefaultReplicationWorker(run):168 - configured sync modes: {null.modifier_list=incremental - append_dedup, null.items=incremental - append_dedup, null.orders=incremental - append_dedup}
2023-09-06 02:10:13 INFO i.a.w.i.DefaultAirbyteDestination(start):92 - Running destination...
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable LAUNCHDARKLY_KEY: ''
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable FEATURE_FLAG_CLIENT: ''
2023-09-06 02:10:13 INFO i.a.c.i.LineGobbler(voidCall):149 - Checking if airbyte/destination-postgres:0.3.27 exists...
2023-09-06 02:10:13 INFO i.a.c.i.LineGobbler(voidCall):149 - airbyte/destination-postgres:0.3.27 was found locally.
2023-09-06 02:10:13 INFO i.a.w.p.DockerProcessFactory(create):139 - Creating docker container = destination-postgres-write-125-2-iqcgx with resources io.airbyte.config.ResourceRequirements@2e10b807[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=,additionalProperties={}] and allowedHosts null
2023-09-06 02:10:13 INFO i.a.w.p.DockerProcessFactory(create):192 - Preparing command: docker run --rm --init -i -w /data/125/2 --log-driver none --name destination-postgres-write-125-2-iqcgx --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e WORKER_CONNECTOR_IMAGE=airbyte/destination-postgres:0.3.27 -e AUTO_DETECT_SCHEMA=true -e LAUNCHDARKLY_KEY= -e SOCAT_KUBE_CPU_REQUEST=0.1 -e SOCAT_KUBE_CPU_LIMIT=2.0 -e USE_STREAM_CAPABLE_STATE=true -e FIELD_SELECTION_WORKSPACES= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_ROLE= -e APPLY_FIELD_SELECTION=false -e WORKER_JOB_ATTEMPT=2 -e OTEL_COLLECTOR_ENDPOINT=http://host.docker.internal:4317 -e FEATURE_FLAG_CLIENT= -e AIRBYTE_VERSION=0.44.5 -e WORKER_JOB_ID=125 airbyte/destination-postgres:0.3.27 write --config destination_config.json --catalog destination_catalog.json
2023-09-06 02:10:13 INFO i.a.w.i.VersionedAirbyteMessageBufferedWriterFactory(createWriter):41 - Writing messages to protocol version 0.2.0
2023-09-06 02:10:13 INFO i.a.w.i.VersionedAirbyteStreamFactory(create):181 - Reading messages from protocol version 0.2.0
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_LIMIT: '2.0'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SIDECAR_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable SOCAT_KUBE_CPU_REQUEST: '0.1'
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable LAUNCHDARKLY_KEY: ''
2023-09-06 02:10:13 INFO i.a.c.EnvConfigs(getEnvOrDefault):1222 - Using default value for environment variable FEATURE_FLAG_CLIENT: ''
2023-09-06 02:10:13 INFO i.a.c.i.LineGobbler(voidCall):149 - Checking if airbyte/source-square:1.1.2 exists...
2023-09-06 02:10:13 INFO i.a.c.i.LineGobbler(voidCall):149 - airbyte/source-square:1.1.2 was found locally.
2023-09-06 02:10:13 INFO i.a.w.p.DockerProcessFactory(create):139 - Creating docker container = source-square-read-125-2-saaed with resources io.airbyte.config.ResourceRequirements@65dc41aa[cpuRequest=,cpuLimit=,memoryRequest=,memoryLimit=,additionalProperties={}] and allowedHosts null
2023-09-06 02:10:13 INFO i.a.w.p.DockerProcessFactory(create):192 - Preparing command: docker run --rm --init -i -w /data/125/2 --log-driver none --name source-square-read-125-2-saaed --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local -e DEPLOYMENT_MODE=OSS -e WORKER_CONNECTOR_IMAGE=airbyte/source-square:1.1.2 -e AUTO_DETECT_SCHEMA=true -e LAUNCHDARKLY_KEY= -e SOCAT_KUBE_CPU_REQUEST=0.1 -e SOCAT_KUBE_CPU_LIMIT=2.0 -e USE_STREAM_CAPABLE_STATE=true -e FIELD_SELECTION_WORKSPACES= -e WORKER_ENVIRONMENT=DOCKER -e AIRBYTE_ROLE= -e APPLY_FIELD_SELECTION=false -e WORKER_JOB_ATTEMPT=2 -e OTEL_COLLECTOR_ENDPOINT=http://host.docker.internal:4317 -e FEATURE_FLAG_CLIENT= -e AIRBYTE_VERSION=0.44.5 -e WORKER_JOB_ID=125 airbyte/source-square:1.1.2 read --config source_config.json --catalog source_catalog.json
2023-09-06 02:10:13 INFO i.a.w.i.VersionedAirbyteStreamFactory(create):181 - Reading messages from protocol version 0.2.0
2023-09-06 02:10:13 INFO i.a.w.g.DefaultReplicationWorker(lambda$readFromDstRunnable$4):289 - Destination output thread started.
2023-09-06 02:10:13 INFO i.a.w.i.HeartbeatTimeoutChaperone(runWithHeartbeatThread):94 - Starting source heartbeat check. Will check every 1 minutes.
2023-09-06 02:10:13 INFO i.a.w.g.DefaultReplicationWorker(lambda$readFromSrcAndWriteToDstRunnable$5):334 - Replication thread started.
2023-09-06 02:10:13 destination > INFO i.a.i.d.p.PostgresDestination(main):98 starting destination: class io.airbyte.integrations.destination.postgres.PostgresDestination
2023-09-06 02:10:14 destination > INFO i.a.i.b.IntegrationCliParser(parseOptions):126 integration args: {catalog=destination_catalog.json, write=null, config=destination_config.json}
2023-09-06 02:10:14 destination > INFO i.a.i.b.IntegrationRunner(runInternal):108 Running integration: io.airbyte.integrations.base.ssh.SshWrappedDestination
2023-09-06 02:10:14 destination > INFO i.a.i.b.IntegrationRunner(runInternal):109 Command: WRITE
2023-09-06 02:10:14 source > Starting syncing SourceSquare
2023-09-06 02:10:14 destination > INFO i.a.i.b.IntegrationRunner(runInternal):110 Integration config: IntegrationConfig{command=WRITE, configPath='destination_config.json', catalogPath='destination_catalog.json', statePath='null'}
2023-09-06 02:10:14 source > Marking stream items as STARTED
2023-09-06 02:10:14 source > {"type": "TRACE", "trace": {"type": "STREAM_STATUS", "emitted_at": 1693966214081.823, "stream_status": {"stream_descriptor": {"name": "items", "namespace": null}, "status": "STARTED"}}}
2023-09-06 02:10:14 source > Syncing stream: items 
2023-09-06 02:10:14 destination > WARN c.n.s.JsonMetaSchema(newValidator):278 Unknown keyword order - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword
2023-09-06 02:10:14 destination > WARN c.n.s.JsonMetaSchema(newValidator):278 Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword
2023-09-06 02:10:14 destination > INFO i.a.i.b.s.SshTunnel(getInstance):204 Starting connection with method: NO_TUNNEL
2023-09-06 02:10:14 destination > INFO c.z.h.HikariDataSource(<init>):80 HikariPool-1 - Starting...
2023-09-06 02:10:14 destination > INFO c.z.h.HikariDataSource(<init>):82 HikariPool-1 - Start completed.
2023-09-06 02:10:14 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 Write config: WriteConfig{streamName=items, namespace=null, outputSchemaName=public, tmpTableName=_airbyte_tmp_yqh_items, outputTableName=_airbyte_raw_items, syncMode=append_dedup}
2023-09-06 02:10:14 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 Write config: WriteConfig{streamName=modifier_list, namespace=null, outputSchemaName=public, tmpTableName=_airbyte_tmp_azd_modifier_list, outputTableName=_airbyte_raw_modifier_list, syncMode=append_dedup}
2023-09-06 02:10:14 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$toWriteConfig$0):98 Write config: WriteConfig{streamName=orders, namespace=null, outputSchemaName=public, tmpTableName=_airbyte_tmp_hon_orders, outputTableName=_airbyte_raw_orders, syncMode=append_dedup}
2023-09-06 02:10:14 destination > INFO i.a.i.d.b.BufferedStreamConsumer(startTracked):146 class io.airbyte.integrations.destination.buffered_stream_consumer.BufferedStreamConsumer started.
2023-09-06 02:10:14 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):134 Preparing raw tables in destination started for 3 streams
2023-09-06 02:10:14 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):139 Preparing raw table in destination started for stream items. schema: public, table name: _airbyte_raw_items
2023-09-06 02:10:16 source > Marking stream items as RUNNING
2023-09-06 02:10:16 source > {"type": "TRACE", "trace": {"type": "STREAM_STATUS", "emitted_at": 1693966216024.162, "stream_status": {"stream_descriptor": {"name": "items", "namespace": null}, "status": "RUNNING"}}}
2023-09-06 02:10:16 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):139 Preparing raw table in destination started for stream modifier_list. schema: public, table name: _airbyte_raw_modifier_list
2023-09-06 02:10:16 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):139 Preparing raw table in destination started for stream orders. schema: public, table name: _airbyte_raw_orders
2023-09-06 02:10:17 destination > INFO i.a.i.d.j.JdbcBufferedConsumerFactory(lambda$onStartFunction$1):152 Preparing raw tables in destination completed.
2023-09-06 02:10:21 source > Encountered an exception while reading stream items
Traceback (most recent call last):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 122, in read
    yield from self._read_stream(
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 197, in _read_stream
    for record in record_iterator:
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 266, in _read_incremental
    for message_counter, record_data_or_message in enumerate(records, start=1):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/declarative_stream.py", line 99, in read_records
    yield from self.retriever.read_records(sync_mode, cursor_field, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 414, in read_records
    most_recent_record_from_slice = self._get_most_recent_record(most_recent_record_from_slice, stream_data, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 428, in _get_most_recent_record
    return current_most_recent if self.cursor.is_greater_than_or_equal(current_most_recent, record) else record
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 274, in is_greater_than_or_equal
    return self.parse_date(first_cursor_value) >= self.parse_date(second_cursor_value)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 187, in parse_date
    return self._parser.parse(date, self.datetime_format)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/datetime/datetime_parser.py", line 29, in parse
    parsed_datetime = datetime.datetime.strptime(str(date), format)
  File "/usr/local/lib/python3.9/_strptime.py", line 568, in _strptime_datetime
    tt, fraction, gmtoff_fraction = _strptime(data_string, format)
  File "/usr/local/lib/python3.9/_strptime.py", line 349, in _strptime
    raise ValueError("time data %r does not match format %r" %
ValueError: time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'
2023-09-06 02:10:21 source > Marking stream items as STOPPED
2023-09-06 02:10:21 source > {"type": "TRACE", "trace": {"type": "STREAM_STATUS", "emitted_at": 1693966221160.84, "stream_status": {"stream_descriptor": {"name": "items", "namespace": null}, "status": "INCOMPLETE"}}}
2023-09-06 02:10:21 source > Finished syncing items
2023-09-06 02:10:21 source > SourceSquare runtimes:
Syncing stream items 0:00:07.079334
2023-09-06 02:10:21 source > time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'
Traceback (most recent call last):
  File "/airbyte/integration_code/main.py", line 13, in <module>
    launch(source, sys.argv[1:])
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 185, in launch
    for message in source_entrypoint.run(parsed_args):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 115, in run
    yield from map(AirbyteEntrypoint.airbyte_message_to_string, self.read(source_spec, config, config_catalog, state))
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/entrypoint.py", line 155, in read
    yield from self.source.read(self.logger, config, catalog, state)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/manifest_declarative_source.py", line 136, in read
    yield from super().read(logger, config, catalog, state)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 142, in read
    raise e
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 122, in read
    yield from self._read_stream(
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 197, in _read_stream
    for record in record_iterator:
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/abstract_source.py", line 266, in _read_incremental
    for message_counter, record_data_or_message in enumerate(records, start=1):
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/declarative_stream.py", line 99, in read_records
    yield from self.retriever.read_records(sync_mode, cursor_field, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 414, in read_records
    most_recent_record_from_slice = self._get_most_recent_record(most_recent_record_from_slice, stream_data, stream_slice)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/retrievers/simple_retriever.py", line 428, in _get_most_recent_record
    return current_most_recent if self.cursor.is_greater_than_or_equal(current_most_recent, record) else record
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 274, in is_greater_than_or_equal
    return self.parse_date(first_cursor_value) >= self.parse_date(second_cursor_value)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/incremental/datetime_based_cursor.py", line 187, in parse_date
    return self._parser.parse(date, self.datetime_format)
  File "/usr/local/lib/python3.9/site-packages/airbyte_cdk/sources/declarative/datetime/datetime_parser.py", line 29, in parse
    parsed_datetime = datetime.datetime.strptime(str(date), format)
  File "/usr/local/lib/python3.9/_strptime.py", line 568, in _strptime_datetime
    tt, fraction, gmtoff_fraction = _strptime(data_string, format)
  File "/usr/local/lib/python3.9/_strptime.py", line 349, in _strptime
    raise ValueError("time data %r does not match format %r" %
ValueError: time data '2021-02-19T18:10:34Z' does not match format '%Y-%m-%dT%H:%M:%S.%fZ'

Contribute

topefolorunso commented 11 months ago

I am unable to reproduce this error @bloodyburger @justinbchau @marcosmarxm. Please confirm you are still getting this error @bloodyburger

KimuchuJr commented 11 months ago

Hello.

I want to contribute.

justinbchau commented 11 months ago

@KimuchuJr I have already assigned you an issue so I will leave this one open to give others a fair chance! If you raise a PR for your issue and this is still open, I can assign.

topefolorunso commented 11 months ago

Please confirm you are still getting this error @bloodyburger as everything works fine on my end.

Krishna-2992 commented 10 months ago

I am interested to work on this issue. kindly assign it to me @bloodyburger @justinbchau

bloodyburger commented 10 months ago

Please confirm you are still getting this error @bloodyburger as everything works fine on my end.

Yes, the issue happens only if I enable items API.