2022-04-19 09:52:18 INFO i.a.w.w.WorkerRun(call):49 - Executing worker wrapper. Airbyte version: 0.35.30-alpha 2022-04-19 09:52:19 INFO i.a.w.t.TemporalAttemptExecution(get):105 - Docker volume job log path: /tmp/workspace/34/2/logs.log 2022-04-19 09:52:19 INFO i.a.w.t.TemporalAttemptExecution(get):110 - Executing worker wrapper. Airbyte version: 0.35.30-alpha 2022-04-19 09:52:19 INFO i.a.w.DefaultReplicationWorker(run):103 - start sync worker. job id: 34 attempt id: 2 2022-04-19 09:52:19 INFO i.a.w.DefaultReplicationWorker(run):115 - configured sync modes: {null.payments=incremental - append_dedup} 2022-04-19 09:52:19 INFO i.a.w.p.a.DefaultAirbyteDestination(start):69 - Running destination... 2022-04-19 09:52:20 INFO i.a.c.i.LineGobbler(voidCall):82 - Checking if airbyte/destination-redshift:0.3.28 exists... 2022-04-19 09:52:20 INFO i.a.c.i.LineGobbler(voidCall):82 - airbyte/destination-redshift:0.3.28 was found locally. 2022-04-19 09:52:20 INFO i.a.w.p.DockerProcessFactory(create):157 - Preparing command: docker run --rm --init -i -w /data/34/2 --log-driver none --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local airbyte/destination-redshift:0.3.28 write --config destination_config.json --catalog destination_catalog.json 2022-04-19 09:52:20 INFO i.a.c.i.LineGobbler(voidCall):82 - Checking if airbyte/source-s3:0.1.10 exists... 2022-04-19 09:52:22 INFO i.a.c.i.LineGobbler(voidCall):82 - airbyte/source-s3:0.1.10 was found locally. 2022-04-19 09:52:22 INFO i.a.w.p.DockerProcessFactory(create):157 - Preparing command: docker run --rm --init -i -w /data/34/2 --log-driver none --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local airbyte/source-s3:0.1.10 read --config source_config.json --catalog source_catalog.json --state input_state.json 2022-04-19 09:52:22 INFO i.a.w.DefaultReplicationWorker(lambda$getDestinationOutputRunnable$6):337 - Destination output thread started. 2022-04-19 09:52:22 INFO i.a.w.DefaultReplicationWorker(run):157 - Waiting for source and destination threads to complete. 2022-04-19 09:52:22 INFO i.a.w.DefaultReplicationWorker(lambda$getReplicationRunnable$5):278 - Replication thread started. 2022-04-19 09:52:30 destination > SLF4J: Class path contains multiple SLF4J bindings. 2022-04-19 09:52:30 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/log4j-slf4j-impl-2.17.1.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-04-19 09:52:30 destination > SLF4J: Found binding in [jar:file:/airbyte/lib/slf4j-log4j12-1.7.25.jar!/org/slf4j/impl/StaticLoggerBinder.class] 2022-04-19 09:52:30 destination > SLF4J: See http://www.slf4j.org/codes.html#multiple_bindings for an explanation. 2022-04-19 09:52:32 destination > SLF4J: Actual binding is of type [org.apache.logging.slf4j.Log4jLoggerFactory] 2022-04-19 09:52:38 source > initialised stream with format: 2022-04-19 09:52:38 source > initialised stream with format: 2022-04-19 09:52:38 source > Starting syncing SourceS3 2022-04-19 09:52:38 source > initialised stream with format: {'encoding': 'UTF-8', 'filetype': 'csv', 'delimiter': ',', 'block_size': 10000, 'quote_char': '"', 'double_quote': False, 'infer_datatypes': False, 'advanced_options': '', 'newlines_in_values': False, 'additional_reader_options': ''} 2022-04-19 09:52:38 source > Syncing stream: payments 2022-04-19 09:52:38 source > Iterating S3 bucket 'travlr-netsuite-prod' with prefix: 'payments/' 2022-04-19 09:52:50 destination > 2022-04-19 09:52:50 INFO i.a.i.d.r.RedshiftDestination(main):77 - starting destination: class io.airbyte.integrations.destination.redshift.RedshiftDestination 2022-04-19 09:52:53 destination > 2022-04-19 09:52:53 INFO i.a.i.b.IntegrationCliParser(parseOptions):118 - integration args: {catalog=destination_catalog.json, write=null, config=destination_config.json} 2022-04-19 09:52:53 destination > 2022-04-19 09:52:53 INFO i.a.i.b.IntegrationRunner(runInternal):121 - Running integration: io.airbyte.integrations.destination.redshift.RedshiftDestination 2022-04-19 09:52:53 destination > 2022-04-19 09:52:53 INFO i.a.i.b.IntegrationRunner(runInternal):122 - Command: WRITE 2022-04-19 09:52:53 destination > 2022-04-19 09:52:53 INFO i.a.i.b.IntegrationRunner(runInternal):123 - Integration config: IntegrationConfig{command=WRITE, configPath='destination_config.json', catalogPath='destination_catalog.json', statePath='null'} 2022-04-19 09:52:56 destination > 2022-04-19 09:52:55 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword examples - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-04-19 09:52:56 destination > 2022-04-19 09:52:55 WARN c.n.s.JsonMetaSchema(newValidator):338 - Unknown keyword airbyte_secret - you should define your own Meta Schema. If the keyword is irrelevant for validation, just use a NonValidationKeyword 2022-04-19 09:52:56 destination > 2022-04-19 09:52:56 INFO i.a.i.d.j.c.SwitchingDestination(getConsumer):65 - Using destination type: COPY_S3 2022-04-19 09:53:00 destination > 2022-04-19 09:53:00 INFO i.a.i.d.s.S3DestinationConfig(createS3Client):169 - Creating S3 client... 2022-04-19 09:53:11 destination > 2022-04-19 09:53:11 INFO i.a.i.d.b.BufferedStreamConsumer(startTracked):141 - class io.airbyte.integrations.destination.buffered_stream_consumer.BufferedStreamConsumer started. 2022-04-19 09:56:01 source > determined master schema: {'BookingDateUtc': 'string', 'PaymentDateAest': 'string', 'OrderId': 'string', 'OrderGuid': 'string', 'PaymentLineNumber': 'string', 'Customerid': 'string', 'Platform': 'string', 'PlatformId': 'string', 'PaymentDateUtc': 'string', 'PaymentStatus': 'string', 'Currency': 'string', 'TransactionId': 'string', 'PaymentChannel': 'string', 'CustomerPaymentAmount': 'string', 'PaymentChannelFeeAccrual': 'string', 'PaymentChannelFeeAccuralGst': 'string', 'PaymentChannelFeeAccuralExcludingGst': 'string', 'AmountExpectedInBank': 'string', 'FraudMonitoringFeeAccrual': 'string', 'FraudMonitoringFeeAccrualGst': 'string', 'FraudMonitoringFeeAccrualExcludingGst': 'string', 'Subsidiary': 'string'} 2022-04-19 09:56:01 source > Encountered an exception while reading stream SourceS3 Traceback (most recent call last): File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/sources/abstract_source.py", line 108, in read internal_config=internal_config, File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/sources/abstract_source.py", line 141, in _read_stream for record in record_iterator: File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/sources/abstract_source.py", line 185, in _read_incremental for record_counter, record_data in enumerate(records, start=1): File "/airbyte/integration_code/source_s3/source_files_abstract/stream.py", line 457, in read_records yield from self._read_from_slice(file_reader, stream_slice) File "/airbyte/integration_code/source_s3/source_files_abstract/stream.py", line 321, in _read_from_slice for record in file_reader.stream_records(f): File "/airbyte/integration_code/source_s3/source_files_abstract/formats/csv_parser.py", line 155, in stream_records pa.csv.ReadOptions(**self._read_options()), File "/airbyte/integration_code/source_s3/source_files_abstract/formats/csv_parser.py", line 45, in _read_options **json.loads(self.format.advanced_options), File "/usr/local/lib/python3.7/json/__init__.py", line 348, in loads return _default_decoder.decode(s) File "/usr/local/lib/python3.7/json/decoder.py", line 337, in decode obj, end = self.raw_decode(s, idx=_w(s, 0).end()) File "/usr/local/lib/python3.7/json/decoder.py", line 355, in raw_decode raise JSONDecodeError("Expecting value", s, err.value) from None json.decoder.JSONDecodeError: Expecting value: line 1 column 1 (char 0) 2022-04-19 09:56:01 source > Finished syncing SourceS3 2022-04-19 09:56:01 source > SourceS3 runtimes: 2022-04-19 09:56:01 source > Expecting value: line 1 column 1 (char 0) Traceback (most recent call last): File "/airbyte/integration_code/main.py", line 13, in launch(source, sys.argv[1:]) File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/entrypoint.py", line 127, in launch for message in source_entrypoint.run(parsed_args): File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/entrypoint.py", line 118, in run for message in generator: File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/sources/abstract_source.py", line 112, in read raise e File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/sources/abstract_source.py", line 108, in read internal_config=internal_config, File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/sources/abstract_source.py", line 141, in _read_stream for record in record_iterator: File "/usr/local/lib/python3.7/site-packages/airbyte_cdk/sources/abstract_source.py", line 185, in _read_incremental for record_counter, record_data in enumerate(records, start=1): File "/airbyte/integration_code/source_s3/source_files_abstract/stream.py", line 457, in read_records yield from self._read_from_slice(file_reader, stream_slice) File "/airbyte/integration_code/source_s3/source_files_abstract/stream.py", line 321, in _read_from_slice for record in file_reader.stream_records(f): File "/airbyte/integration_code/source_s3/source_files_abstract/formats/csv_parser.py", line 155, in stream_records pa.csv.ReadOptions(**self._read_options()), File "/airbyte/integration_code/source_s3/source_files_abstract/formats/csv_parser.py", line 45, in _read_options **json.loads(self.format.advanced_options), File "/usr/local/lib/python3.7/json/__init__.py", line 348, in loads return _default_decoder.decode(s) File "/usr/local/lib/python3.7/json/decoder.py", line 337, in decode obj, end = self.raw_decode(s, idx=_w(s, 0).end()) File "/usr/local/lib/python3.7/json/decoder.py", line 355, in raw_decode raise JSONDecodeError("Expecting value", s, err.value) from None json.decoder.JSONDecodeError: Expecting value: line 1 column 1 (char 0) 2022-04-19 09:56:01 destination > 2022-04-19 09:56:01 INFO i.a.i.b.FailureTrackingAirbyteMessageConsumer(close):65 - Airbyte message consumer: succeeded. 2022-04-19 09:56:01 destination > 2022-04-19 09:56:01 INFO i.a.i.d.b.BufferedStreamConsumer(close):217 - executing on success close procedure. 2022-04-19 09:56:01 destination > 2022-04-19 09:56:01 INFO i.a.i.d.b.BufferedStreamConsumer(flushQueueToDestination):181 - Flushing buffer: 0 bytes 2022-04-19 09:56:01 destination > 2022-04-19 09:56:01 INFO i.a.i.d.j.c.s.S3StreamCopier(createDestinationSchema):152 - Creating schema in destination if it doesn't exist: netsuite 2022-04-19 09:56:02 destination > 2022-04-19 09:56:02 INFO i.a.i.d.j.c.s.S3StreamCopier(createTemporaryTable):158 - Preparing tmp table in destination for stream: payments, schema: netsuite, tmp table name: _airbyte_tmp_uzk_payments. 2022-04-19 09:56:02 destination > 2022-04-19 09:56:02 INFO i.a.i.d.r.RedshiftStreamCopier(copyStagingFileToTemporaryTable):85 - Starting copy to tmp table: _airbyte_tmp_uzk_payments in destination for stream: payments, schema: netsuite, . 2022-04-19 09:56:02 destination > 2022-04-19 09:56:02 INFO i.a.i.d.r.RedshiftStreamCopier(copyStagingFileToTemporaryTable):89 - Copy to tmp table _airbyte_tmp_uzk_payments in destination for stream payments complete. 2022-04-19 09:56:02 destination > 2022-04-19 09:56:02 INFO i.a.i.d.j.c.s.S3StreamCopier(createDestinationTable):174 - Preparing table _airbyte_raw_payments in destination. 2022-04-19 09:56:02 destination > 2022-04-19 09:56:02 INFO i.a.i.d.j.c.s.S3StreamCopier(createDestinationTable):176 - Table _airbyte_tmp_uzk_payments in destination prepared. 2022-04-19 09:56:02 destination > 2022-04-19 09:56:02 INFO i.a.i.d.j.c.s.S3StreamCopier(generateMergeStatement):183 - Preparing to merge tmp table _airbyte_tmp_uzk_payments to dest table: _airbyte_raw_payments, schema: netsuite, in destination. 2022-04-19 09:56:03 destination > 2022-04-19 09:56:03 INFO i.a.i.d.j.c.s.S3StreamCopier(removeFileAndDropTmpTable):202 - Begin cleaning _airbyte_tmp_uzk_payments tmp table in destination. 2022-04-19 09:56:03 destination > 2022-04-19 09:56:03 INFO i.a.i.d.j.c.s.S3StreamCopier(removeFileAndDropTmpTable):204 - _airbyte_tmp_uzk_payments tmp table in destination cleaned. 2022-04-19 09:56:03 destination > 2022-04-19 09:56:03 INFO i.a.i.b.IntegrationRunner(runInternal):169 - Completed integration: io.airbyte.integrations.destination.redshift.RedshiftDestination 2022-04-19 09:56:03 destination > 2022-04-19 09:56:03 INFO i.a.i.d.r.RedshiftDestination(main):79 - completed destination: class io.airbyte.integrations.destination.redshift.RedshiftDestination 2022-04-19 09:56:03 ERROR i.a.w.DefaultReplicationWorker(run):168 - Sync worker failed. java.util.concurrent.ExecutionException: io.airbyte.workers.DefaultReplicationWorker$SourceException: Source process exited with non-zero exit code 1 at java.util.concurrent.CompletableFuture.reportGet(CompletableFuture.java:396) ~[?:?] at java.util.concurrent.CompletableFuture.get(CompletableFuture.java:2073) ~[?:?] at io.airbyte.workers.DefaultReplicationWorker.run(DefaultReplicationWorker.java:161) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at io.airbyte.workers.DefaultReplicationWorker.run(DefaultReplicationWorker.java:56) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:155) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at java.lang.Thread.run(Thread.java:833) [?:?] Suppressed: io.airbyte.workers.WorkerException: Source process exit with code 1. This warning is normal if the job was cancelled. at io.airbyte.workers.protocols.airbyte.DefaultAirbyteSource.close(DefaultAirbyteSource.java:136) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at io.airbyte.workers.DefaultReplicationWorker.run(DefaultReplicationWorker.java:125) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at io.airbyte.workers.DefaultReplicationWorker.run(DefaultReplicationWorker.java:56) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at io.airbyte.workers.temporal.TemporalAttemptExecution.lambda$getWorkerThread$2(TemporalAttemptExecution.java:155) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at java.lang.Thread.run(Thread.java:833) [?:?] Caused by: io.airbyte.workers.DefaultReplicationWorker$SourceException: Source process exited with non-zero exit code 1 at io.airbyte.workers.DefaultReplicationWorker.lambda$getReplicationRunnable$5(DefaultReplicationWorker.java:310) ~[io.airbyte-airbyte-workers-0.35.30-alpha.jar:?] at java.util.concurrent.CompletableFuture$AsyncRun.run(CompletableFuture.java:1804) ~[?:?] at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1136) ~[?:?] at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:635) ~[?:?] ... 1 more 2022-04-19 09:56:03 INFO i.a.w.DefaultReplicationWorker(run):227 - sync summary: io.airbyte.config.ReplicationAttemptSummary@3ccfba40[status=failed,recordsSynced=0,bytesSynced=0,startTime=1650361939995,endTime=1650362163182,totalStats=io.airbyte.config.SyncStats@5b05aaef[recordsEmitted=0,bytesEmitted=0,stateMessagesEmitted=0,recordsCommitted=0],streamStats=[]] 2022-04-19 09:56:03 INFO i.a.w.DefaultReplicationWorker(run):249 - Source did not output any state messages 2022-04-19 09:56:03 WARN i.a.w.DefaultReplicationWorker(run):257 - State capture: No new state, falling back on input state: io.airbyte.config.State@7216e2f9[state={}] 2022-04-19 09:56:03 INFO i.a.w.t.TemporalAttemptExecution(get):131 - Stopping cancellation check scheduling... 2022-04-19 09:56:03 INFO i.a.w.t.s.ReplicationActivityImpl(lambda$replicate$1):144 - sync summary: io.airbyte.config.StandardSyncOutput@558aab[standardSyncSummary=io.airbyte.config.StandardSyncSummary@6098adc8[status=failed,recordsSynced=0,bytesSynced=0,startTime=1650361939995,endTime=1650362163182,totalStats=io.airbyte.config.SyncStats@5b05aaef[recordsEmitted=0,bytesEmitted=0,stateMessagesEmitted=0,recordsCommitted=0],streamStats=[]],state=io.airbyte.config.State@7216e2f9[state={}],outputCatalog=io.airbyte.protocol.models.ConfiguredAirbyteCatalog@78a46183[streams=[io.airbyte.protocol.models.ConfiguredAirbyteStream@31ace717[stream=io.airbyte.protocol.models.AirbyteStream@1d00235b[name=payments,jsonSchema={"type":"object","properties":{"OrderId":{"type":["null","string"]},"Currency":{"type":["null","string"]},"Platform":{"type":["null","string"]},"OrderGuid":{"type":["null","string"]},"Customerid":{"type":["null","string"]},"PlatformId":{"type":["null","string"]},"Subsidiary":{"type":["null","string"]},"PaymentStatus":{"type":["null","string"]},"TransactionId":{"type":["null","string"]},"BookingDateUtc":{"type":["null","string"]},"PaymentChannel":{"type":["null","string"]},"PaymentDateUtc":{"type":["null","string"]},"PaymentDateAest":{"type":["null","string"]},"PaymentLineNumber":{"type":["null","string"]},"_ab_source_file_url":{"type":"string"},"AmountExpectedInBank":{"type":["null","string"]},"CustomerPaymentAmount":{"type":["null","string"]},"PaymentChannelFeeAccrual":{"type":["null","string"]},"FraudMonitoringFeeAccrual":{"type":["null","string"]},"_ab_additional_properties":{"type":"object"},"PaymentChannelFeeAccuralGst":{"type":["null","string"]},"FraudMonitoringFeeAccrualGst":{"type":["null","string"]},"_ab_source_file_last_modified":{"type":"string","format":"date-time"},"PaymentChannelFeeAccuralExcludingGst":{"type":["null","string"]},"FraudMonitoringFeeAccrualExcludingGst":{"type":["null","string"]}}},supportedSyncModes=[full_refresh, incremental],sourceDefinedCursor=true,defaultCursorField=[_ab_source_file_last_modified],sourceDefinedPrimaryKey=[],namespace=,additionalProperties={}],syncMode=incremental,cursorField=[_ab_source_file_last_modified],destinationSyncMode=append_dedup,primaryKey=[[OrderGuid]],additionalProperties={}]],additionalProperties={}],failures=[io.airbyte.config.FailureReason@38d33bde[failureOrigin=source,failureType=,internalMessage=io.airbyte.workers.DefaultReplicationWorker$SourceException: Source process exited with non-zero exit code 1,externalMessage=Something went wrong within the source connector,metadata=io.airbyte.config.Metadata@63a0ed3e[additionalProperties={attemptNumber=2, jobId=34}],stacktrace=java.util.concurrent.CompletionException: io.airbyte.workers.DefaultReplicationWorker$SourceException: Source process exited with non-zero exit code 1 at java.base/java.util.concurrent.CompletableFuture.encodeThrowable(CompletableFuture.java:315) at java.base/java.util.concurrent.CompletableFuture.completeThrowable(CompletableFuture.java:320) at java.base/java.util.concurrent.CompletableFuture$AsyncRun.run(CompletableFuture.java:1807) at java.base/java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1136) at java.base/java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:635) at java.base/java.lang.Thread.run(Thread.java:833) Caused by: io.airbyte.workers.DefaultReplicationWorker$SourceException: Source process exited with non-zero exit code 1 at io.airbyte.workers.DefaultReplicationWorker.lambda$getReplicationRunnable$5(DefaultReplicationWorker.java:310) at java.base/java.util.concurrent.CompletableFuture$AsyncRun.run(CompletableFuture.java:1804) ... 3 more ,retryable=,timestamp=1650362161601]]] 2022-04-19 09:56:03 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):234 - Stopping temporal heartbeating... 2022-04-19 09:56:03 INFO i.a.c.p.ConfigRepository(updateConnectionState):545 - Updating connection 97f37cde-59f1-45bb-a0cf-3ed0ecf5ae5f state: io.airbyte.config.State@8481e37[state={}] 2022-04-19 09:56:03 INFO i.a.w.t.TemporalAttemptExecution(get):105 - Docker volume job log path: /tmp/workspace/34/2/logs.log 2022-04-19 09:56:03 INFO i.a.w.t.TemporalAttemptExecution(get):110 - Executing worker wrapper. Airbyte version: 0.35.30-alpha 2022-04-19 09:56:03 INFO i.a.w.DefaultNormalizationWorker(run):46 - Running normalization. 2022-04-19 09:56:03 INFO i.a.w.n.DefaultNormalizationRunner(runProcess):122 - Running with normalization version: airbyte/normalization:0.1.66 2022-04-19 09:56:03 INFO i.a.c.i.LineGobbler(voidCall):82 - Checking if airbyte/normalization:0.1.66 exists... 2022-04-19 09:56:03 INFO i.a.c.i.LineGobbler(voidCall):82 - airbyte/normalization:0.1.66 was found locally. 2022-04-19 09:56:03 INFO i.a.w.p.DockerProcessFactory(create):157 - Preparing command: docker run --rm --init -i -w /data/34/2/normalize --log-driver none --network host -v airbyte_workspace:/data -v /tmp/airbyte_local:/local airbyte/normalization:0.1.66 run --integration-type redshift --config destination_config.json --catalog destination_catalog.json 2022-04-19 09:56:03 normalization > Running: transform-config --config destination_config.json --integration-type redshift --out /data/34/2/normalize 2022-04-19 09:56:04 normalization > Namespace(config='destination_config.json', integration_type=, out='/data/34/2/normalize') 2022-04-19 09:56:04 normalization > transform_redshift 2022-04-19 09:56:04 normalization > Running: transform-catalog --integration-type redshift --profile-config-dir /data/34/2/normalize --catalog destination_catalog.json --out /data/34/2/normalize/models/generated/ --json-column _airbyte_data 2022-04-19 09:56:04 normalization > Processing destination_catalog.json... 2022-04-19 09:56:04 normalization > Generating airbyte_ctes/netsuite/payments_ab1.sql from payments 2022-04-19 09:56:04 normalization > Generating airbyte_ctes/netsuite/payments_ab2.sql from payments 2022-04-19 09:56:04 normalization > Generating airbyte_views/netsuite/payments_stg.sql from payments 2022-04-19 09:56:04 normalization > Generating airbyte_incremental/scd/netsuite/payments_scd.sql from payments 2022-04-19 09:56:04 normalization > Generating airbyte_incremental/netsuite/payments.sql from payments 2022-04-19 09:56:04 normalization > detected no config file for ssh, assuming ssh is off. 2022-04-19 09:56:06 normalization > Running with dbt=0.21.1 2022-04-19 09:56:07 normalization > Unable to do partial parsing because ../build/partial_parse.msgpack not found 2022-04-19 09:56:09 normalization > [WARNING]: Configuration paths exist in your dbt_project.yml file which do not apply to any resources. 2022-04-19 09:56:09 normalization > There are 1 unused configuration paths: 2022-04-19 09:56:09 normalization > - models.airbyte_utils.generated.airbyte_tables 2022-04-19 09:56:09 normalization > 2022-04-19 09:56:09 normalization > Found 5 models, 0 tests, 0 snapshots, 0 analyses, 520 macros, 0 operations, 0 seed files, 1 source, 0 exposures 2022-04-19 09:56:09 normalization > 2022-04-19 09:56:09 normalization > 09:56:09 | Concurrency: 4 threads (target='prod') 2022-04-19 09:56:09 normalization > 09:56:09 | 2022-04-19 09:56:09 normalization > 09:56:09 | 1 of 3 START view model _airbyte_netsuite.payments_stg....................................................... [RUN] 2022-04-19 09:56:10 normalization > 09:56:10 | 1 of 3 OK created view model _airbyte_netsuite.payments_stg.................................................. [CREATE VIEW in 0.44s] 2022-04-19 09:56:10 normalization > 09:56:10 | 2 of 3 START incremental model netsuite.payments_scd......................................................... [RUN] 2022-04-19 09:56:13 normalization > 09:56:13 | 2 of 3 OK created incremental model netsuite.payments_scd.................................................... [INSERT 0 0 in 2.81s] 2022-04-19 09:56:13 normalization > 09:56:13 | 3 of 3 START incremental model netsuite.payments............................................................. [RUN] 2022-04-19 09:56:14 normalization > 09:56:14 | 3 of 3 OK created incremental model netsuite.payments........................................................ [INSERT 0 0 in 1.49s] 2022-04-19 09:56:14 normalization > 09:56:14 | 2022-04-19 09:56:14 normalization > 09:56:14 | Finished running 1 view model, 2 incremental models in 5.40s. 2022-04-19 09:56:14 normalization > 2022-04-19 09:56:14 normalization > Completed successfully 2022-04-19 09:56:14 normalization > 2022-04-19 09:56:14 normalization > Done. PASS=3 WARN=0 ERROR=0 SKIP=0 TOTAL=3 2022-04-19 09:56:15 INFO i.a.w.DefaultNormalizationWorker(run):69 - Normalization executed in 11 seconds. 2022-04-19 09:56:15 INFO i.a.w.t.TemporalAttemptExecution(get):131 - Stopping cancellation check scheduling... 2022-04-19 09:56:15 INFO i.a.w.t.TemporalUtils(withBackgroundHeartbeat):234 - Stopping temporal heartbeating...