Replies: 1 comment 1 reply
-
@vinod303 Based on the logs, it is trying to download files from the |
Beta Was this translation helpful? Give feedback.
1 reply
Sign up for free
to join this conversation on GitHub.
Already have an account?
Sign in to comment
-
We have noticed that the the ECML contents are failing with the following error.
SBED version: 7.0
Instance: GCP
Scenario:
Content is failed is with the following message.
"publishError": "Error parsing input: null\n{statusCode=200, message=OK, headers={Server=[UploadServer], ETag=[CLiVy4fZvosDEAE=], X-GUploader-UploadID=[AHMx-iFrtGf0WUXQqbo0RCS4kDUIUOXPFGHm3teDfwNd0KfO5sq0B3GmPTCmWAsH4feL7qg2Ihd8Fw], Vary=[X-Origin, Origin], Date=[Thu, 13 Feb 2025 09:33:57 GMT]}, payload=[content=true, contentMetadata=[cacheControl=private, max-age=0, must-revalidate, no-transform, contentDisposition=null, contentEncoding=null, contentLanguage=null, contentLength=1210, contentMD5=null, contentType=application/json; charset=UTF-8, expires=Thu Feb 13 09:33:57 UTC 2025], written=false, isSensitive=false]}",
Also pasting the detailed log.
` ... 35 more
Caused by: java.lang.NullPointerException
at org.jclouds.json.internal.NullFilteringTypeAdapterFactories$MapTypeAdapter.read(NullFilteringTypeAdapterFactories.java:319)
at org.jclouds.json.internal.NullFilteringTypeAdapterFactories$MapTypeAdapter.read(NullFilteringTypeAdapterFactories.java:287)
at org.jclouds.json.internal.DeserializationConstructorAndReflectiveTypeAdapterFactory$ParameterReader.read(DeserializationConstructorAndReflectiveTypeAdapterFactory.java:275)
at org.jclouds.json.internal.DeserializationConstructorAndReflectiveTypeAdapterFactory$DeserializeIntoParameterizedConstructor.read(DeserializationConstructorAndReflectiveTypeAdapterFactory.java:187)
at com.google.gson.Gson.fromJson(Gson.java:814)
at com.google.gson.Gson.fromJson(Gson.java:779)
at org.jclouds.json.internal.GsonWrapper.fromJson(GsonWrapper.java:55)
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:82)
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:76)
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:61)
... 50 more
2025-02-13 09:33:57,566 INFO org.apache.flink.runtime.taskmanager.Task ] - Freeing task resources for publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#0 (67bab1711b38cb0be774f1e56a89f13f).
2025-02-13 09:33:57,567 INFO org.apache.flink.runtime.taskexecutor.TaskExecutor ] - Un-registering task and sending final execution state FAILED to JobManager for task publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#0 67bab1711b38cb0be774f1e56a89f13f.
2025-02-13 09:33:57,656 INFO org.apache.flink.runtime.taskmanager.Task ] - Attempting to cancel task Source: content-publish-consumer (1/1)#0 (ab3deb391775978421e274c886cebd35).
2025-02-13 09:33:57,656 INFO org.apache.flink.runtime.taskmanager.Task ] - Source: content-publish-consumer (1/1)#0 (ab3deb391775978421e274c886cebd35) switched from RUNNING to CANCELING.
2025-02-13 09:33:57,656 INFO org.apache.flink.runtime.taskmanager.Task ] - Triggering cancellation of task code Source: content-publish-consumer (1/1)#0 (ab3deb391775978421e274c886cebd35).
2025-02-13 09:33:57,659 INFO org.apache.flink.runtime.taskmanager.Task ] - Source: content-publish-consumer (1/1)#0 (ab3deb391775978421e274c886cebd35) switched from CANCELING to CANCELED.
2025-02-13 09:33:57,659 INFO org.apache.flink.runtime.taskmanager.Task ] - Freeing task resources for Source: content-publish-consumer (1/1)#0 (ab3deb391775978421e274c886cebd35).
2025-02-13 09:33:57,659 INFO org.apache.flink.runtime.taskexecutor.TaskExecutor ] - Un-registering task and sending final execution state CANCELED to JobManager for task Source: content-publish-consumer (1/1)#0 ab3deb391775978421e274c886cebd35.
2025-02-13 09:34:27,712 INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl ] - Activate slot 87490e25b26e9da8c9d2fd82454976ce.
2025-02-13 09:34:27,714 INFO org.apache.flink.runtime.taskexecutor.TaskExecutor ] - Received task Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46), deploy into slot with allocation id 87490e25b26e9da8c9d2fd82454976ce.
2025-02-13 09:34:27,715 INFO org.apache.flink.runtime.taskexecutor.slot.TaskSlotTableImpl ] - Activate slot 87490e25b26e9da8c9d2fd82454976ce.
2025-02-13 09:34:27,715 INFO org.apache.flink.runtime.taskmanager.Task ] - Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46) switched from CREATED to DEPLOYING.
2025-02-13 09:34:27,716 INFO org.apache.flink.runtime.taskmanager.Task ] - Loading JAR files for task Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46) [DEPLOYING].
2025-02-13 09:34:27,716 INFO org.apache.flink.streaming.runtime.tasks.StreamTask ] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@10462130
2025-02-13 09:34:27,716 INFO org.apache.flink.streaming.runtime.tasks.StreamTask ] - Checkpoint storage is set to 'jobmanager'
2025-02-13 09:34:27,717 INFO org.apache.flink.runtime.taskmanager.Task ] - Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46) switched from DEPLOYING to INITIALIZING.
2025-02-13 09:34:27,717 INFO org.apache.flink.runtime.taskexecutor.TaskExecutor ] - Received task publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 (e3fdb34885230fe3834b243075ebfb1e), deploy into slot with allocation id 87490e25b26e9da8c9d2fd82454976ce.
2025-02-13 09:34:27,717 INFO org.apache.flink.runtime.taskmanager.Task ] - publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 (e3fdb34885230fe3834b243075ebfb1e) switched from CREATED to DEPLOYING.
2025-02-13 09:34:27,718 INFO org.apache.flink.runtime.taskmanager.Task ] - Loading JAR files for task publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 (e3fdb34885230fe3834b243075ebfb1e) [DEPLOYING].
2025-02-13 09:34:27,720 INFO org.apache.flink.streaming.runtime.tasks.StreamTask ] - No state backend has been configured, using default (HashMap) org.apache.flink.runtime.state.hashmap.HashMapStateBackend@4ca15114
2025-02-13 09:34:27,720 INFO org.apache.flink.streaming.runtime.tasks.StreamTask ] - Checkpoint storage is set to 'jobmanager'
2025-02-13 09:34:27,720 INFO org.apache.flink.runtime.taskmanager.Task ] - publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 (e3fdb34885230fe3834b243075ebfb1e) switched from DEPLOYING to INITIALIZING.
2025-02-13 09:34:27,723 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase ] - Consumer subtask 0 restored state: {KafkaTopicPartition{topic='dev.knowlg.publish.job.request', partition=0}=36}.
2025-02-13 09:34:27,729 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase ] - Consumer subtask 0 will start reading 1 partitions with offsets in restored state: {KafkaTopicPartition{topic='dev.knowlg.publish.job.request', partition=0}=36}
2025-02-13 09:34:27,729 INFO org.apache.flink.runtime.taskmanager.Task ] - Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46) switched from INITIALIZING to RUNNING.
2025-02-13 09:34:27,732 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase ] - Consumer subtask 0 creating fetcher with offsets {KafkaTopicPartition{topic='dev.knowlg.publish.job.request', partition=0}=36}.
2025-02-13 09:34:27,732 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - restoring state
2025-02-13 09:34:27,732 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 committed recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439128214}
2025-02-13 09:34:27,732 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 aborted recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439188214}
2025-02-13 09:34:27,732 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - no state to restore
2025-02-13 09:34:27,735 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer ] - Starting FlinkKafkaInternalProducer (1/1) to produce into default topic dev.knowlg.content.postpublish.request
2025-02-13 09:34:27,749 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - restoring state
2025-02-13 09:34:27,749 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 committed recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439128214}
2025-02-13 09:34:27,749 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 aborted recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439188214}
2025-02-13 09:34:27,749 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - no state to restore
2025-02-13 09:34:27,751 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer ] - Starting FlinkKafkaInternalProducer (1/1) to produce into default topic dev.knowlg.mvc.processor.job.request
2025-02-13 09:34:27,769 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - restoring state
2025-02-13 09:34:27,769 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 committed recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439128214}
2025-02-13 09:34:27,769 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 aborted recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439188214}
2025-02-13 09:34:27,769 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - no state to restore
2025-02-13 09:34:27,771 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer ] - Starting FlinkKafkaInternalProducer (1/1) to produce into default topic dev.knowlg.learning.events.failed
2025-02-13 09:34:27,777 INFO com.datastax.driver.core.ClockFactory ] - Using java.lang.System clock to generate timestamps.
2025-02-13 09:34:27,801 INFO com.datastax.driver.core.policies.DCAwareRoundRobinPolicy ] - Using data-center name 'datacenter1' for DCAwareRoundRobinPolicy (if this is incorrect, please provide the correct datacenter name with DCAwareRoundRobinPolicy constructor)
2025-02-13 09:34:27,801 INFO com.datastax.driver.core.Cluster ] - New Cassandra host cassandra/34.118.225.106:9042 added
Feb 13, 2025 9:34:27 AM org.neo4j.driver.internal.logging.JULogger info
INFO: Direct driver instance 486675394 created for server address neo4j:7687
2025-02-13 09:34:27,864 INFO org.sunbird.job.cache.RedisConnect ] - Obtaining new Redis connection... : for host :redis-master and port: 6379
2025-02-13 09:34:27,869 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - restoring state
2025-02-13 09:34:27,869 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 committed recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439128214}
2025-02-13 09:34:27,869 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 aborted recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439188214}
2025-02-13 09:34:27,869 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - no state to restore
2025-02-13 09:34:27,871 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer ] - Starting FlinkKafkaInternalProducer (1/1) to produce into default topic dev.knowlg.content.postpublish.request
2025-02-13 09:34:27,877 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - restoring state
2025-02-13 09:34:27,877 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 committed recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439128214}
2025-02-13 09:34:27,877 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 aborted recovered transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439188214}
2025-02-13 09:34:27,877 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - no state to restore
2025-02-13 09:34:27,878 INFO org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer ] - Starting FlinkKafkaInternalProducer (1/1) to produce into default topic dev.knowlg.learning.events.failed
2025-02-13 09:34:27,884 INFO com.datastax.driver.core.ClockFactory ] - Using java.lang.System clock to generate timestamps.
2025-02-13 09:34:27,919 INFO com.datastax.driver.core.policies.DCAwareRoundRobinPolicy ] - Using data-center name 'datacenter1' for DCAwareRoundRobinPolicy (if this is incorrect, please provide the correct datacenter name with DCAwareRoundRobinPolicy constructor)
2025-02-13 09:34:27,919 INFO com.datastax.driver.core.Cluster ] - New Cassandra host cassandra/34.118.225.106:9042 added
Feb 13, 2025 9:34:27 AM org.neo4j.driver.internal.logging.JULogger info
INFO: Direct driver instance 2044734618 created for server address neo4j:7687
2025-02-13 09:34:27,970 INFO org.sunbird.job.cache.RedisConnect ] - Obtaining new Redis connection... : for host :redis-master and port: 6379
2025-02-13 09:34:27,974 INFO org.apache.flink.runtime.taskmanager.Task ] - publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 (e3fdb34885230fe3834b243075ebfb1e) switched from INITIALIZING to RUNNING.
2025-02-13 09:34:27,976 INFO org.sunbird.job.content.function.PublishEventRouter ] - PublishEventRouter :: Event: JobRequest {map={actor=Map(id -> content-publish, type -> System), eid=BE_JOB_REQUEST, edata=Map(publish_type -> public, contentType -> Resource, iteration -> 1, metadata -> Map(identifier -> do_214249485877665792160, mimeType -> application/vnd.ekstep.ecml-archive, objectType -> Content, lastPublishedBy -> 2b0c53fa-ba8e-4a86-a31d-56e855dd854c, pkgVersion -> 0), action -> publish), ets=1739439236916, context=Map(pdata -> Map(ver -> 1.0, id -> org.sunbird.platform), channel -> 0142374959972352000, env -> dev), mid=LP.1739439236916.4832de78-3776-4d5e-a228-8f1a4185d00d, object=Map(ver -> 1739439212639, id -> do_214249485877665792160)}}
2025-02-13 09:34:27,977 INFO org.sunbird.job.content.function.PublishEventRouter ] - PublishEventRouter :: Sending Content For Publish Having Identifier: do_214249485877665792160
2025-02-13 09:34:27,978 INFO org.sunbird.job.content.function.ContentPublishFunction ] - Content publishing started for : do_214249485877665792160
2025-02-13 09:34:27,978 INFO org.sunbird.job.publish.helpers.ObjectReader ] - Reading editable object data for: do_214249485877665792160 with pkgVersion: 0.0
2025-02-13 09:34:27,984 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath ::: data before url replace :: {ownershipType=[createdBy], copyright=Sunbird Org, plugins=[{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}], subject=[English], channel=0142374959972352000, organisation=[Sunbird Org], language=[English], mimeType=application/vnd.ekstep.ecml-archive, editorState={"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"75d97d28-1546-4394-8b36-1dc6b024be15","selectedPluginObject":"1c951dde-17d1-4818-87d8-c4ca500480c5"},"sidebar":{"selectedMenu":"settings"}}, gradeLevel=[Class 1], assets=], primaryCategory=Teacher Resource, contentEncoding=gzip, lockKey=cdf7c8c8-58fb-41d6-b842-81e7df1f786d, contentType=Resource, trackable={"enabled":"No","autoBatch":"No"}, lastUpdatedBy=6f7d22ec-277a-4ad4-a191-718403a21135, audience=[Student], visibility=Default, consumerId=861d6b6b-ff63-4e0b-a167-bbcb4be744a1, discussionForum={"enabled":"No"}, mediaType=content, osId=org.ekstep.quiz.app, lastPublishedBy=2b0c53fa-ba8e-4a86-a31d-56e855dd854c, version=2, pragma=], prevState=Review, license=CC BY 4.0, IL_FUNC_OBJECT_TYPE=Content, name=ECMLTest-log test, status=Failed, totalQuestions=0, interceptionPoints={}, code=org.sunbird.ib7BnG, publishError=Error parsing input: null
{statusCode=200, message=OK, headers={Server=[UploadServer], ETag=[CLiVy4fZvosDEAE=], X-GUploader-UploadID=[AHMx-iFrtGf0WUXQqbo0RCS4kDUIUOXPFGHm3teDfwNd0KfO5sq0B3GmPTCmWAsH4feL7qg2Ihd8Fw], Vary=[X-Origin, Origin], Date=[Thu, 13 Feb 2025 09:33:57 GMT]}, payload=[content=true, contentMetadata=[cacheControl=private, max-age=0, must-revalidate, no-transform, contentDisposition=null, contentEncoding=null, contentLanguage=null, contentLength=1210, contentMD5=null, contentType=application/json; charset=UTF-8, expires=Thu Feb 13 09:33:57 UTC 2025], written=false, isSensitive=false]}, credentials={"enabled":"No"}, description=Enter description for Resource, medium=[English], idealScreenSize=normal, createdOn=2025-02-13T09:33:14.062+0000, contentDisposition=inline, lastUpdatedOn=2025-02-13T09:33:57.497+0000, dialcodeRequired=No, creator=Content Creator, createdFor=[0142374959972352000], lastStatusChangedOn=2025-02-13T09:33:57.497+0000, os=[All], IL_SYS_NODE_TYPE=DATA_NODE, totalScore=0, pkgVersion=1.0, versionKey=1739439212639, idealScreenDensity=hdpi, framework=NCF, lastSubmittedOn=2025-02-13T09:33:32.628+0000, createdBy=6f7d22ec-277a-4ad4-a191-718403a21135, compatibilityLevel=1, IL_UNIQUE_ID=do_214249485877665792160, board=State (Maharashtra), resourceType=Teach}
2025-02-13 09:34:27,984 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath ::: data after url replace :: {copyright=Sunbird Org, lastStatusChangedOn=2025-02-13T09:33:57.497+0000, organisation=[Sunbird Org], mediaType=content, name=ECMLTest-log test, discussionForum={"enabled":"No"}, createdOn=2025-02-13T09:33:14.062+0000, createdFor=[0142374959972352000], channel=0142374959972352000, assets=], plugins=[{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}], lastUpdatedOn=2025-02-13T09:33:57.497+0000, subject=[English], IL_FUNC_OBJECT_TYPE=Content, publishError=Error parsing input: null
{statusCode=200, message=OK, headers={Server=[UploadServer], ETag=[CLiVy4fZvosDEAE=], X-GUploader-UploadID=[AHMx-iFrtGf0WUXQqbo0RCS4kDUIUOXPFGHm3teDfwNd0KfO5sq0B3GmPTCmWAsH4feL7qg2Ihd8Fw], Vary=[X-Origin, Origin], Date=[Thu, 13 Feb 2025 09:33:57 GMT]}, payload=[content=true, contentMetadata=[cacheControl=private, max-age=0, must-revalidate, no-transform, contentDisposition=null, contentEncoding=null, contentLanguage=null, contentLength=1210, contentMD5=null, contentType=application/json; charset=UTF-8, expires=Thu Feb 13 09:33:57 UTC 2025], written=false, isSensitive=false]}, editorState={"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"75d97d28-1546-4394-8b36-1dc6b024be15","selectedPluginObject":"1c951dde-17d1-4818-87d8-c4ca500480c5"},"sidebar":{"selectedMenu":"settings"}}, description=Enter description for Resource, resourceType=Teach, gradeLevel=[Class 1], ownershipType=[createdBy], compatibilityLevel=1, audience=[Student], trackable={"enabled":"No","autoBatch":"No"}, os=[All], primaryCategory=Teacher Resource, IL_SYS_NODE_TYPE=DATA_NODE, lockKey=cdf7c8c8-58fb-41d6-b842-81e7df1f786d, medium=[English], framework=NCF, creator=Content Creator, versionKey=1739439212639, mimeType=application/vnd.ekstep.ecml-archive, code=org.sunbird.ib7BnG, license=CC BY 4.0, version=2, contentType=Resource, prevState=Review, language=[English], board=State (Maharashtra), totalQuestions=0, totalScore=0, lastUpdatedBy=6f7d22ec-277a-4ad4-a191-718403a21135, status=Failed, pragma=], createdBy=6f7d22ec-277a-4ad4-a191-718403a21135, dialcodeRequired=No, lastSubmittedOn=2025-02-13T09:33:32.628+0000, interceptionPoints={}, idealScreenSize=normal, contentEncoding=gzip, consumerId=861d6b6b-ff63-4e0b-a167-bbcb4be744a1, lastPublishedBy=2b0c53fa-ba8e-4a86-a31d-56e855dd854c, osId=org.ekstep.quiz.app, IL_UNIQUE_ID=do_214249485877665792160, contentDisposition=inline, visibility=Default, credentials={"enabled":"No"}, pkgVersion=1.0, idealScreenDensity=hdpi}
2025-02-13 09:34:27,984 INFO org.sunbird.job.publish.helpers.ObjectReader ] - ObjectReader:: getMetadata:: identifier: do_214249485877665792160 with objType: Content
2025-02-13 09:34:27,984 INFO org.sunbird.job.publish.helpers.ObjectReader ] - Reading metadata for: do_214249485877665792160 with metadata: Map(copyright -> Sunbird Org, lastStatusChangedOn -> 2025-02-13T09:33:57.497+0000, publish_type -> public, organisation -> [Sunbird Org], mediaType -> content, name -> ECMLTest-log test, discussionForum -> {"enabled":"No"}, createdOn -> 2025-02-13T09:33:14.062+0000, createdFor -> [0142374959972352000], channel -> 0142374959972352000, assets -> ], plugins -> [{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}], lastUpdatedOn -> 2025-02-13T09:33:57.497+0000, subject -> [English], publishError -> Error parsing input: null
{statusCode=200, message=OK, headers={Server=[UploadServer], ETag=[CLiVy4fZvosDEAE=], X-GUploader-UploadID=[AHMx-iFrtGf0WUXQqbo0RCS4kDUIUOXPFGHm3teDfwNd0KfO5sq0B3GmPTCmWAsH4feL7qg2Ihd8Fw], Vary=[X-Origin, Origin], Date=[Thu, 13 Feb 2025 09:33:57 GMT]}, payload=[content=true, contentMetadata=[cacheControl=private, max-age=0, must-revalidate, no-transform, contentDisposition=null, contentEncoding=null, contentLanguage=null, contentLength=1210, contentMD5=null, contentType=application/json; charset=UTF-8, expires=Thu Feb 13 09:33:57 UTC 2025], written=false, isSensitive=false]}, editorState -> {"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"75d97d28-1546-4394-8b36-1dc6b024be15","selectedPluginObject":"1c951dde-17d1-4818-87d8-c4ca500480c5"},"sidebar":{"selectedMenu":"settings"}}, identifier -> do_214249485877665792160, description -> Enter description for Resource, resourceType -> Teach, gradeLevel -> [Class 1], ownershipType -> [createdBy], compatibilityLevel -> 1, audience -> [Student], trackable -> {"enabled":"No","autoBatch":"No"}, os -> [All], primaryCategory -> Teacher Resource, lockKey -> cdf7c8c8-58fb-41d6-b842-81e7df1f786d, medium -> [English], framework -> NCF, creator -> Content Creator, versionKey -> 1739439212639, mimeType -> application/vnd.ekstep.ecml-archive, code -> org.sunbird.ib7BnG, license -> CC BY 4.0, version -> 2, contentType -> Resource, prevState -> Review, language -> [English], board -> State (Maharashtra), totalQuestions -> 0, totalScore -> 0, objectType -> Content, lastUpdatedBy -> 6f7d22ec-277a-4ad4-a191-718403a21135, status -> Failed, pragma -> ], createdBy -> 6f7d22ec-277a-4ad4-a191-718403a21135, dialcodeRequired -> No, lastSubmittedOn -> 2025-02-13T09:33:32.628+0000, interceptionPoints -> {}, idealScreenSize -> normal, contentEncoding -> gzip, consumerId -> 861d6b6b-ff63-4e0b-a167-bbcb4be744a1, lastPublishedBy -> 2b0c53fa-ba8e-4a86-a31d-56e855dd854c, osId -> org.ekstep.quiz.app, contentDisposition -> inline, visibility -> Default, credentials -> {"enabled":"No"}, pkgVersion -> 1.0, idealScreenDensity -> hdpi)
2025-02-13 09:34:27,984 INFO org.sunbird.job.publish.helpers.ObjectUpdater ] - ObjectUpdater:: getContentBody:: Cassandra Fetch Query for image:: SELECT blobAsText(body) AS body FROM dev_content_store.content_data WHERE content_id='do_214249485877665792160.img';
2025-02-13 09:34:27,985 INFO org.sunbird.job.publish.helpers.ObjectUpdater ] - ObjectUpdater:: getContentBody:: Cassandra Fetch Query :: SELECT blobAsText(body) AS body FROM dev_content_store.content_data WHERE content_id='do_214249485877665792160';
2025-02-13 09:34:27,986 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath String ::: data before url replace :: {"theme":{"id":"theme","version":"1.0","startStage":"75d97d28-1546-4394-8b36-1dc6b024be15","stage":[{"x":0,"y":0,"w":100,"h":100,"id":"75d97d28-1546-4394-8b36-1dc6b024be15","rotate":null,"config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"color":"#FFFFFF","genieControls":false,"instructions":""}"},"manifest":{"media":]},"org.ekstep.text":[{"x":10,"y":20,"minWidth":20,"w":35,"maxWidth":500,"fill":"#000000","fontStyle":"normal","fontWeight":"normal","stroke":"rgba(255, 255, 255, 0)","strokeWidth":1,"opacity":1,"editable":false,"version":"V2","offsetY":0.2,"h":5.02,"rotate":0,"textType":"text","lineHeight":1,"z-index":0,"font":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":48,"weight":"","id":"1c951dde-17d1-4818-87d8-c4ca500480c5","config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"text":"Test","color":"#000000","fontfamily":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":18,"fontweight":false,"fontstyle":false,"align":"left"}"}}]}],"manifest":{"media":[{"id":"a2bb83a6-ab83-4ed4-b3cd-2b4147b09ec7","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/controller/navigation_ctrl.js","type":"js"},{"id":"04e9428e-a49b-480d-84c7-3550a222b7d3","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/templates/navigation.html","type":"js"},{"id":"org.ekstep.navigation","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/plugin.js","type":"plugin"},{"id":"org.ekstep.navigation_manifest","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/manifest.json","type":"json"},{"id":"org.ekstep.text","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/renderer/supertextplugin.js","type":"plugin"},{"id":"org.ekstep.text_manifest","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/manifest.json","type":"json"}]},"plugin-manifest":{"plugin":[{"id":"org.ekstep.navigation","ver":"1.0","type":"plugin","depends":""},{"id":"org.ekstep.text","ver":"1.2","type":"plugin","depends":""}]},"compatibilityVersion":2}}
2025-02-13 09:34:27,986 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath String ::: data after url replace :: {"theme":{"id":"theme","version":"1.0","startStage":"75d97d28-1546-4394-8b36-1dc6b024be15","stage":[{"x":0,"y":0,"w":100,"h":100,"id":"75d97d28-1546-4394-8b36-1dc6b024be15","rotate":null,"config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"color":"#FFFFFF","genieControls":false,"instructions":""}"},"manifest":{"media":]},"org.ekstep.text":[{"x":10,"y":20,"minWidth":20,"w":35,"maxWidth":500,"fill":"#000000","fontStyle":"normal","fontWeight":"normal","stroke":"rgba(255, 255, 255, 0)","strokeWidth":1,"opacity":1,"editable":false,"version":"V2","offsetY":0.2,"h":5.02,"rotate":0,"textType":"text","lineHeight":1,"z-index":0,"font":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":48,"weight":"","id":"1c951dde-17d1-4818-87d8-c4ca500480c5","config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"text":"Test","color":"#000000","fontfamily":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":18,"fontweight":false,"fontstyle":false,"align":"left"}"}}]}],"manifest":{"media":[{"id":"a2bb83a6-ab83-4ed4-b3cd-2b4147b09ec7","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/controller/navigation_ctrl.js","type":"js"},{"id":"04e9428e-a49b-480d-84c7-3550a222b7d3","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/templates/navigation.html","type":"js"},{"id":"org.ekstep.navigation","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/plugin.js","type":"plugin"},{"id":"org.ekstep.navigation_manifest","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/manifest.json","type":"json"},{"id":"org.ekstep.text","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/renderer/supertextplugin.js","type":"plugin"},{"id":"org.ekstep.text_manifest","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/manifest.json","type":"json"}]},"plugin-manifest":{"plugin":[{"id":"org.ekstep.navigation","ver":"1.0","type":"plugin","depends":""},{"id":"org.ekstep.text","ver":"1.2","type":"plugin","depends":""}]},"compatibilityVersion":2}}
2025-02-13 09:34:27,987 INFO org.sunbird.job.publish.helpers.ObjectReader ] - Reading extData for: do_214249485877665792160 with extData: Some(ObjectExtData(Some(Map(body -> {"theme":{"id":"theme","version":"1.0","startStage":"75d97d28-1546-4394-8b36-1dc6b024be15","stage":[{"x":0,"y":0,"w":100,"h":100,"id":"75d97d28-1546-4394-8b36-1dc6b024be15","rotate":null,"config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"color":"#FFFFFF","genieControls":false,"instructions":""}"},"manifest":{"media":]},"org.ekstep.text":[{"x":10,"y":20,"minWidth":20,"w":35,"maxWidth":500,"fill":"#000000","fontStyle":"normal","fontWeight":"normal","stroke":"rgba(255, 255, 255, 0)","strokeWidth":1,"opacity":1,"editable":false,"version":"V2","offsetY":0.2,"h":5.02,"rotate":0,"textType":"text","lineHeight":1,"z-index":0,"font":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":48,"weight":"","id":"1c951dde-17d1-4818-87d8-c4ca500480c5","config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"text":"Test","color":"#000000","fontfamily":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":18,"fontweight":false,"fontstyle":false,"align":"left"}"}}]}],"manifest":{"media":[{"id":"a2bb83a6-ab83-4ed4-b3cd-2b4147b09ec7","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/controller/navigation_ctrl.js","type":"js"},{"id":"04e9428e-a49b-480d-84c7-3550a222b7d3","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/templates/navigation.html","type":"js"},{"id":"org.ekstep.navigation","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/plugin.js","type":"plugin"},{"id":"org.ekstep.navigation_manifest","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/manifest.json","type":"json"},{"id":"org.ekstep.text","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/renderer/supertextplugin.js","type":"plugin"},{"id":"org.ekstep.text_manifest","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/manifest.json","type":"json"}]},"plugin-manifest":{"plugin":[{"id":"org.ekstep.navigation","ver":"1.0","type":"plugin","depends":""},{"id":"org.ekstep.text","ver":"1.2","type":"plugin","depends":""}]},"compatibilityVersion":2}})),None))
2025-02-13 09:34:27,987 INFO org.sunbird.job.content.function.ContentPublishFunction ] - pkgVersion should be greater than or equal to the obj.pkgVersion for : do_214249485877665792160
2025-02-13 09:35:02,170 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 9 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439267749} from checkpoint 9
2025-02-13 09:35:02,170 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 9 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439267768} from checkpoint 9
2025-02-13 09:35:02,170 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 9 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439267775} from checkpoint 9
2025-02-13 09:35:02,170 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 9 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439267876} from checkpoint 9
2025-02-13 09:35:02,170 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 9 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439267883} from checkpoint 9
2025-02-13 09:36:02,168 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 10 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439302164} from checkpoint 10
2025-02-13 09:36:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 10 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439302164} from checkpoint 10
2025-02-13 09:36:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 10 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439302164} from checkpoint 10
2025-02-13 09:36:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 10 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439302164} from checkpoint 10
2025-02-13 09:36:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 10 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439302164} from checkpoint 10
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────2025-02-13 09:37:02,168 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 11 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439362164} from checkpoint 11
2025-02-13 09:37:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 11 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439362164} from checkpoint 11
2025-02-13 09:37:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 11 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439362164} from checkpoint 11
2025-02-13 09:37:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 11 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439362164} from checkpoint 11
2025-02-13 09:37:02,169 INFO org.apache.flink.streaming.api.functions.sink.TwoPhaseCommitSinkFunction ] - FlinkKafkaProducer 1/1 - checkpoint 11 complete, committing transaction TransactionHolder{handle=KafkaTransactionState [transactionalId=null, producerId=-1, epoch=-1], transactionStartTime=1739439362164} from checkpoint 11
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────
────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────────2025-02-13 09:37:49,663 INFO org.sunbird.job.content.function.PublishEventRouter ] - PublishEventRouter :: Event: JobRequest {map={actor=Map(id -> content-publish, type -> System), eid=BE_JOB_REQUEST, edata=Map(publish_type -> public, contentType -> Resource, iteration -> 1, metadata -> Map(identifier -> do_214249487624437760161, mimeType -> application/vnd.ekstep.ecml-archive, objectType -> Content, lastPublishedBy -> 2b0c53fa-ba8e-4a86-a31d-56e855dd854c, pkgVersion -> 0), action -> publish), ets=1739439469558, context=Map(pdata -> Map(ver -> 1.0, id -> org.sunbird.platform), channel -> 0142374959972352000, env -> dev), mid=LP.1739439469558.226ccc58-6a5a-4d0e-bbcf-e3a18cfad2f5, object=Map(ver -> 1739439425989, id -> do_214249487624437760161)}}
2025-02-13 09:37:49,665 INFO org.sunbird.job.content.function.PublishEventRouter ] - PublishEventRouter :: Sending Content For Publish Having Identifier: do_214249487624437760161
2025-02-13 09:37:49,666 INFO org.sunbird.job.content.function.ContentPublishFunction ] - Content publishing started for : do_214249487624437760161
2025-02-13 09:37:49,668 INFO org.sunbird.job.publish.helpers.ObjectReader ] - Reading editable object data for: do_214249487624437760161 with pkgVersion: 0.0
2025-02-13 09:37:49,677 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath ::: data before url replace :: {ownershipType=[createdBy], copyright=Sunbird Org, plugins=[{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}], subject=[English], channel=0142374959972352000, organisation=[Sunbird Org], language=[English], mimeType=application/vnd.ekstep.ecml-archive, editorState={"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","selectedPluginObject":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2"},"sidebar":{"selectedMenu":"settings"}}, gradeLevel=[Class 1], assets=], primaryCategory=Teacher Resource, contentEncoding=gzip, lockKey=3aa01313-0964-430d-9c58-1441caa4873a, contentType=Resource, trackable={"enabled":"No","autoBatch":"No"}, lastUpdatedBy=6f7d22ec-277a-4ad4-a191-718403a21135, audience=[Student], visibility=Default, consumerId=861d6b6b-ff63-4e0b-a167-bbcb4be744a1, discussionForum={"enabled":"No"}, mediaType=content, osId=org.ekstep.quiz.app, version=2, pragma=], license=CC BY 4.0, IL_FUNC_OBJECT_TYPE=Content, name=ECML-LGTEST - 3, status=Review, totalQuestions=0, interceptionPoints={}, code=org.sunbird.m0hru0, credentials={"enabled":"No"}, description=Enter description for Resource, medium=[English], idealScreenSize=normal, createdOn=2025-02-13T09:36:47.290+0000, contentDisposition=inline, lastUpdatedOn=2025-02-13T09:37:05.989+0000, dialcodeRequired=No, creator=Content Creator, createdFor=[0142374959972352000], lastStatusChangedOn=2025-02-13T09:36:47.290+0000, os=[All], IL_SYS_NODE_TYPE=DATA_NODE, totalScore=0, versionKey=1739439425989, idealScreenDensity=hdpi, framework=NCF, lastSubmittedOn=2025-02-13T09:37:05.979+0000, createdBy=6f7d22ec-277a-4ad4-a191-718403a21135, compatibilityLevel=1, IL_UNIQUE_ID=do_214249487624437760161, board=State (Maharashtra), resourceType=Teach}
2025-02-13 09:37:49,677 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath ::: data after url replace :: {copyright=Sunbird Org, lastStatusChangedOn=2025-02-13T09:36:47.290+0000, organisation=[Sunbird Org], mediaType=content, name=ECML-LGTEST - 3, discussionForum={"enabled":"No"}, createdOn=2025-02-13T09:36:47.290+0000, createdFor=[0142374959972352000], channel=0142374959972352000, assets=], plugins=[{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}], lastUpdatedOn=2025-02-13T09:37:05.989+0000, subject=[English], IL_FUNC_OBJECT_TYPE=Content, editorState={"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","selectedPluginObject":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2"},"sidebar":{"selectedMenu":"settings"}}, description=Enter description for Resource, resourceType=Teach, gradeLevel=[Class 1], ownershipType=[createdBy], compatibilityLevel=1, audience=[Student], trackable={"enabled":"No","autoBatch":"No"}, os=[All], primaryCategory=Teacher Resource, IL_SYS_NODE_TYPE=DATA_NODE, lockKey=3aa01313-0964-430d-9c58-1441caa4873a, medium=[English], framework=NCF, creator=Content Creator, versionKey=1739439425989, mimeType=application/vnd.ekstep.ecml-archive, code=org.sunbird.m0hru0, license=CC BY 4.0, version=2, contentType=Resource, language=[English], board=State (Maharashtra), totalQuestions=0, totalScore=0, lastUpdatedBy=6f7d22ec-277a-4ad4-a191-718403a21135, status=Review, pragma=], createdBy=6f7d22ec-277a-4ad4-a191-718403a21135, dialcodeRequired=No, lastSubmittedOn=2025-02-13T09:37:05.979+0000, interceptionPoints={}, idealScreenSize=normal, contentEncoding=gzip, consumerId=861d6b6b-ff63-4e0b-a167-bbcb4be744a1, osId=org.ekstep.quiz.app, IL_UNIQUE_ID=do_214249487624437760161, contentDisposition=inline, visibility=Default, credentials={"enabled":"No"}, idealScreenDensity=hdpi}
2025-02-13 09:37:49,677 INFO org.sunbird.job.publish.helpers.ObjectReader ] - ObjectReader:: getMetadata:: identifier: do_214249487624437760161 with objType: Content
2025-02-13 09:37:49,677 INFO org.sunbird.job.publish.helpers.ObjectReader ] - Reading metadata for: do_214249487624437760161 with metadata: Map(copyright -> Sunbird Org, lastStatusChangedOn -> 2025-02-13T09:36:47.290+0000, publish_type -> public, organisation -> [Sunbird Org], mediaType -> content, name -> ECML-LGTEST - 3, discussionForum -> {"enabled":"No"}, createdOn -> 2025-02-13T09:36:47.290+0000, createdFor -> [0142374959972352000], channel -> 0142374959972352000, assets -> ], plugins -> [{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}], lastUpdatedOn -> 2025-02-13T09:37:05.989+0000, subject -> [English], editorState -> {"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","selectedPluginObject":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2"},"sidebar":{"selectedMenu":"settings"}}, identifier -> do_214249487624437760161, description -> Enter description for Resource, resourceType -> Teach, gradeLevel -> [Class 1], ownershipType -> [createdBy], compatibilityLevel -> 1, audience -> [Student], trackable -> {"enabled":"No","autoBatch":"No"}, os -> [All], primaryCategory -> Teacher Resource, lockKey -> 3aa01313-0964-430d-9c58-1441caa4873a, medium -> [English], framework -> NCF, creator -> Content Creator, versionKey -> 1739439425989, mimeType -> application/vnd.ekstep.ecml-archive, code -> org.sunbird.m0hru0, license -> CC BY 4.0, version -> 2, contentType -> Resource, language -> [English], board -> State (Maharashtra), totalQuestions -> 0, totalScore -> 0, objectType -> Content, lastUpdatedBy -> 6f7d22ec-277a-4ad4-a191-718403a21135, status -> Review, pragma -> ], createdBy -> 6f7d22ec-277a-4ad4-a191-718403a21135, dialcodeRequired -> No, lastSubmittedOn -> 2025-02-13T09:37:05.979+0000, interceptionPoints -> {}, idealScreenSize -> normal, contentEncoding -> gzip, consumerId -> 861d6b6b-ff63-4e0b-a167-bbcb4be744a1, osId -> org.ekstep.quiz.app, contentDisposition -> inline, visibility -> Default, credentials -> {"enabled":"No"}, idealScreenDensity -> hdpi)
2025-02-13 09:37:49,678 INFO org.sunbird.job.publish.helpers.ObjectUpdater ] - ObjectUpdater:: getContentBody:: Cassandra Fetch Query for image:: SELECT blobAsText(body) AS body FROM dev_content_store.content_data WHERE content_id='do_214249487624437760161.img';
2025-02-13 09:37:49,679 INFO org.sunbird.job.publish.helpers.ObjectUpdater ] - ObjectUpdater:: getContentBody:: Cassandra Fetch Query :: SELECT blobAsText(body) AS body FROM dev_content_store.content_data WHERE content_id='do_214249487624437760161';
2025-02-13 09:37:49,680 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath String ::: data before url replace :: {"theme":{"id":"theme","version":"1.0","startStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","stage":[{"x":0,"y":0,"w":100,"h":100,"id":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","rotate":null,"config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"color":"#FFFFFF","genieControls":false,"instructions":""}"},"manifest":{"media":]},"org.ekstep.text":[{"x":10,"y":20,"minWidth":20,"w":35,"maxWidth":500,"fill":"#000000","fontStyle":"normal","fontWeight":"normal","stroke":"rgba(255, 255, 255, 0)","strokeWidth":1,"opacity":1,"editable":false,"version":"V2","offsetY":0.2,"h":5.02,"rotate":0,"textType":"text","lineHeight":1,"z-index":0,"font":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":48,"weight":"","id":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2","config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"text":"Test","color":"#000000","fontfamily":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":18,"fontweight":false,"fontstyle":false,"align":"left"}"}}]}],"manifest":{"media":[{"id":"b9539788-c828-4510-879d-5a8750003b7b","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/controller/navigation_ctrl.js","type":"js"},{"id":"7bb56eca-dd6c-404a-b02a-60363c16c9d0","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/templates/navigation.html","type":"js"},{"id":"org.ekstep.navigation","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/plugin.js","type":"plugin"},{"id":"org.ekstep.navigation_manifest","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/manifest.json","type":"json"},{"id":"org.ekstep.text","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/renderer/supertextplugin.js","type":"plugin"},{"id":"org.ekstep.text_manifest","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/manifest.json","type":"json"}]},"plugin-manifest":{"plugin":[{"id":"org.ekstep.navigation","ver":"1.0","type":"plugin","depends":""},{"id":"org.ekstep.text","ver":"1.2","type":"plugin","depends":""}]},"compatibilityVersion":2}}
2025-02-13 09:37:49,681 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateAbsolutePath String ::: data after url replace :: {"theme":{"id":"theme","version":"1.0","startStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","stage":[{"x":0,"y":0,"w":100,"h":100,"id":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","rotate":null,"config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"color":"#FFFFFF","genieControls":false,"instructions":""}"},"manifest":{"media":]},"org.ekstep.text":[{"x":10,"y":20,"minWidth":20,"w":35,"maxWidth":500,"fill":"#000000","fontStyle":"normal","fontWeight":"normal","stroke":"rgba(255, 255, 255, 0)","strokeWidth":1,"opacity":1,"editable":false,"version":"V2","offsetY":0.2,"h":5.02,"rotate":0,"textType":"text","lineHeight":1,"z-index":0,"font":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":48,"weight":"","id":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2","config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"text":"Test","color":"#000000","fontfamily":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":18,"fontweight":false,"fontstyle":false,"align":"left"}"}}]}],"manifest":{"media":[{"id":"b9539788-c828-4510-879d-5a8750003b7b","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/controller/navigation_ctrl.js","type":"js"},{"id":"7bb56eca-dd6c-404a-b02a-60363c16c9d0","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/templates/navigation.html","type":"js"},{"id":"org.ekstep.navigation","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/plugin.js","type":"plugin"},{"id":"org.ekstep.navigation_manifest","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/manifest.json","type":"json"},{"id":"org.ekstep.text","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/renderer/supertextplugin.js","type":"plugin"},{"id":"org.ekstep.text_manifest","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/manifest.json","type":"json"}]},"plugin-manifest":{"plugin":[{"id":"org.ekstep.navigation","ver":"1.0","type":"plugin","depends":""},{"id":"org.ekstep.text","ver":"1.2","type":"plugin","depends":""}]},"compatibilityVersion":2}}
2025-02-13 09:37:49,682 INFO org.sunbird.job.publish.helpers.ObjectReader ] - Reading extData for: do_214249487624437760161 with extData: Some(ObjectExtData(Some(Map(body -> {"theme":{"id":"theme","version":"1.0","startStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","stage":[{"x":0,"y":0,"w":100,"h":100,"id":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","rotate":null,"config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"color":"#FFFFFF","genieControls":false,"instructions":""}"},"manifest":{"media":]},"org.ekstep.text":[{"x":10,"y":20,"minWidth":20,"w":35,"maxWidth":500,"fill":"#000000","fontStyle":"normal","fontWeight":"normal","stroke":"rgba(255, 255, 255, 0)","strokeWidth":1,"opacity":1,"editable":false,"version":"V2","offsetY":0.2,"h":5.02,"rotate":0,"textType":"text","lineHeight":1,"z-index":0,"font":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":48,"weight":"","id":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2","config":{"__cdata":"{"opacity":100,"strokeWidth":1,"stroke":"rgba(255, 255, 255, 0)","autoplay":false,"visible":true,"text":"Test","color":"#000000","fontfamily":"'Noto Sans', 'Noto Sans Bengali', 'Noto Sans Malayalam', 'Noto Sans Gurmukhi', 'Noto Sans Devanagari', 'Noto Sans Gujarati', 'Noto Sans Telugu', 'Noto Sans Tamil', 'Noto Sans Kannada', 'Noto Sans Oriya', 'Noto Nastaliq Urdu', -apple-system, BlinkMacSystemFont, Roboto, Oxygen-Sans, Ubuntu, Cantarell, 'Helvetica Neue'","fontsize":18,"fontweight":false,"fontstyle":false,"align":"left"}"}}]}],"manifest":{"media":[{"id":"b9539788-c828-4510-879d-5a8750003b7b","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/controller/navigation_ctrl.js","type":"js"},{"id":"7bb56eca-dd6c-404a-b02a-60363c16c9d0","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/templates/navigation.html","type":"js"},{"id":"org.ekstep.navigation","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/renderer/plugin.js","type":"plugin"},{"id":"org.ekstep.navigation_manifest","plugin":"org.ekstep.navigation","ver":"1.0","src":"/content-plugins/org.ekstep.navigation-1.0/manifest.json","type":"json"},{"id":"org.ekstep.text","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/renderer/supertextplugin.js","type":"plugin"},{"id":"org.ekstep.text_manifest","plugin":"org.ekstep.text","ver":"1.2","src":"/content-plugins/org.ekstep.text-1.2/manifest.json","type":"json"}]},"plugin-manifest":{"plugin":[{"id":"org.ekstep.navigation","ver":"1.0","type":"plugin","depends":""},{"id":"org.ekstep.text","ver":"1.2","type":"plugin","depends":""}]},"compatibilityVersion":2}})),None))
2025-02-13 09:37:49,683 INFO org.sunbird.job.publish.helpers.ObjectValidator ] - Validating object with id: do_214249487624437760161
2025-02-13 09:37:49,683 INFO org.sunbird.job.content.publish.helpers.ContentPublisher ] - Validating Content metadata for : do_214249487624437760161
2025-02-13 09:37:49,870 INFO org.sunbird.job.publish.helpers.ObjectUpdater ] - ObjectUpdater:: updateProcessingNode:: Query: MATCH (n:domain{IL_UNIQUE_ID:"do_214249487624437760161"}) SET n.status="Processing",n.prevState="Review",n.copyright="Sunbird Org",n.organisation=["Sunbird Org"],n.mediaType="content",n.name="ECML-LGTEST - 3",n.discussionForum="{"enabled":"No"}",n.createdOn="2025-02-13T09:36:47.290+0000",n.createdFor=["0142374959972352000"],n.channel="0142374959972352000",n.assets=],n.plugins="[{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}]",n.subject=["English"],n.editorState="{"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","selectedPluginObject":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2"},"sidebar":{"selectedMenu":"settings"}}",n.description="Enter description for Resource",n.resourceType="Teach",n.gradeLevel=["Class 1"],n.ownershipType=["createdBy"],n.compatibilityLevel=1,n.audience=["Student"],n.trackable="{"enabled":"No","autoBatch":"No"}",n.os=["All"],n.primaryCategory="Teacher Resource",n.lockKey="3aa01313-0964-430d-9c58-1441caa4873a",n.medium=["English"],n.framework="NCF",n.creator="Content Creator",n.versionKey="1739439425989",n.mimeType="application/vnd.ekstep.ecml-archive",n.code="org.sunbird.m0hru0",n.license="CC BY 4.0",n.version=2,n.contentType="Resource",n.language=["English"],n.board="State (Maharashtra)",n.totalQuestions=0,n.totalScore=0,n.lastUpdatedBy="6f7d22ec-277a-4ad4-a191-718403a21135",n.pragma=],n.createdBy="6f7d22ec-277a-4ad4-a191-718403a21135",n.dialcodeRequired="No",n.lastSubmittedOn="2025-02-13T09:37:05.979+0000",n.interceptionPoints="{}",n.idealScreenSize="normal",n.contentEncoding="gzip",n.consumerId="861d6b6b-ff63-4e0b-a167-bbcb4be744a1",n.lastPublishedBy="2b0c53fa-ba8e-4a86-a31d-56e855dd854c",n.osId="org.ekstep.quiz.app",n.contentDisposition="inline",n.visibility="Default",n.credentials="{"enabled":"No"}",n.idealScreenDensity="hdpi",n.lastUpdatedOn="2025-02-13T09:37:49.870+0000",n.lastStatusChangedOn="2025-02-13T09:37:49.870+0000";
2025-02-13 09:37:49,870 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateRelativePath ::: query before url replace :: MATCH (n:domain{IL_UNIQUE_ID:"do_214249487624437760161"}) SET n.status="Processing",n.prevState="Review",n.copyright="Sunbird Org",n.organisation=["Sunbird Org"],n.mediaType="content",n.name="ECML-LGTEST - 3",n.discussionForum="{"enabled":"No"}",n.createdOn="2025-02-13T09:36:47.290+0000",n.createdFor=["0142374959972352000"],n.channel="0142374959972352000",n.assets=],n.plugins="[{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}]",n.subject=["English"],n.editorState="{"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","selectedPluginObject":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2"},"sidebar":{"selectedMenu":"settings"}}",n.description="Enter description for Resource",n.resourceType="Teach",n.gradeLevel=["Class 1"],n.ownershipType=["createdBy"],n.compatibilityLevel=1,n.audience=["Student"],n.trackable="{"enabled":"No","autoBatch":"No"}",n.os=["All"],n.primaryCategory="Teacher Resource",n.lockKey="3aa01313-0964-430d-9c58-1441caa4873a",n.medium=["English"],n.framework="NCF",n.creator="Content Creator",n.versionKey="1739439425989",n.mimeType="application/vnd.ekstep.ecml-archive",n.code="org.sunbird.m0hru0",n.license="CC BY 4.0",n.version=2,n.contentType="Resource",n.language=["English"],n.board="State (Maharashtra)",n.totalQuestions=0,n.totalScore=0,n.lastUpdatedBy="6f7d22ec-277a-4ad4-a191-718403a21135",n.pragma=],n.createdBy="6f7d22ec-277a-4ad4-a191-718403a21135",n.dialcodeRequired="No",n.lastSubmittedOn="2025-02-13T09:37:05.979+0000",n.interceptionPoints="{}",n.idealScreenSize="normal",n.contentEncoding="gzip",n.consumerId="861d6b6b-ff63-4e0b-a167-bbcb4be744a1",n.lastPublishedBy="2b0c53fa-ba8e-4a86-a31d-56e855dd854c",n.osId="org.ekstep.quiz.app",n.contentDisposition="inline",n.visibility="Default",n.credentials="{"enabled":"No"}",n.idealScreenDensity="hdpi",n.lastUpdatedOn="2025-02-13T09:37:49.870+0000",n.lastStatusChangedOn="2025-02-13T09:37:49.870+0000";
2025-02-13 09:37:49,870 INFO org.sunbird.job.util.CSPMetaUtil ] - CSPMetaUtil ::: updateRelativePath ::: query after url replace :: MATCH (n:domain{IL_UNIQUE_ID:"do_214249487624437760161"}) SET n.status="Processing",n.prevState="Review",n.copyright="Sunbird Org",n.organisation=["Sunbird Org"],n.mediaType="content",n.name="ECML-LGTEST - 3",n.discussionForum="{"enabled":"No"}",n.createdOn="2025-02-13T09:36:47.290+0000",n.createdFor=["0142374959972352000"],n.channel="0142374959972352000",n.assets=],n.plugins="[{"identifier":"org.ekstep.stage","semanticVersion":"1.0"},{"identifier":"org.ekstep.text","semanticVersion":"1.2"},{"identifier":"org.ekstep.navigation","semanticVersion":"1.0"}]",n.subject=["English"],n.editorState="{"plugin":{"noOfExtPlugins":12,"extPlugins":[{"plugin":"org.ekstep.contenteditorfunctions","version":"1.2"},{"plugin":"org.ekstep.keyboardshortcuts","version":"1.0"},{"plugin":"org.ekstep.richtext","version":"1.0"},{"plugin":"org.ekstep.iterator","version":"1.0"},{"plugin":"org.ekstep.navigation","version":"1.0"},{"plugin":"org.ekstep.reviewercomments","version":"1.0"},{"plugin":"org.ekstep.questionunit.mtf","version":"1.2"},{"plugin":"org.ekstep.questionunit.mcq","version":"1.3"},{"plugin":"org.ekstep.keyboard","version":"1.1"},{"plugin":"org.ekstep.questionunit.reorder","version":"1.1"},{"plugin":"org.ekstep.questionunit.sequence","version":"1.1"},{"plugin":"org.ekstep.questionunit.ftb","version":"1.1"}]},"stage":{"noOfStages":1,"currentStage":"eea72d03-62b0-4815-8b6e-e9ecbd7c3896","selectedPluginObject":"9d2c5737-a4d6-4b02-aed7-c6b9a8db1ed2"},"sidebar":{"selectedMenu":"settings"}}",n.description="Enter description for Resource",n.resourceType="Teach",n.gradeLevel=["Class 1"],n.ownershipType=["createdBy"],n.compatibilityLevel=1,n.audience=["Student"],n.trackable="{"enabled":"No","autoBatch":"No"}",n.os=["All"],n.primaryCategory="Teacher Resource",n.lockKey="3aa01313-0964-430d-9c58-1441caa4873a",n.medium=["English"],n.framework="NCF",n.creator="Content Creator",n.versionKey="1739439425989",n.mimeType="application/vnd.ekstep.ecml-archive",n.code="org.sunbird.m0hru0",n.license="CC BY 4.0",n.version=2,n.contentType="Resource",n.language=["English"],n.board="State (Maharashtra)",n.totalQuestions=0,n.totalScore=0,n.lastUpdatedBy="6f7d22ec-277a-4ad4-a191-718403a21135",n.pragma=],n.createdBy="6f7d22ec-277a-4ad4-a191-718403a21135",n.dialcodeRequired="No",n.lastSubmittedOn="2025-02-13T09:37:05.979+0000",n.interceptionPoints="{}",n.idealScreenSize="normal",n.contentEncoding="gzip",n.consumerId="861d6b6b-ff63-4e0b-a167-bbcb4be744a1",n.lastPublishedBy="2b0c53fa-ba8e-4a86-a31d-56e855dd854c",n.osId="org.ekstep.quiz.app",n.contentDisposition="inline",n.visibility="Default",n.credentials="{"enabled":"No"}",n.idealScreenDensity="hdpi",n.lastUpdatedOn="2025-02-13T09:37:49.870+0000",n.lastStatusChangedOn="2025-02-13T09:37:49.870+0000";
2025-02-13 09:37:49,896 INFO ExtractableMimeTypeHelper ] - ExtractableMimeTypeHelper ::: downloadAssetFiles ::: Processing file: b9539788-c828-4510-879d-5a8750003b7b for : do_214249487624437760161
2025-02-13 09:37:49,897 INFO ExtractableMimeTypeHelper ] - ExtractableMimeTypeHelper ::: downloadAssetFiles ::: fDownloadPath: /tmp/contentBundle/1739439469895_tmp/do_214249487624437760161/widgets/content-plugins/org.ekstep.navigation-1.0/renderer/controller/ & src : /content-plugins/org.ekstep.navigation-1.0/renderer/controller/navigation_ctrl.js
... 35 more
Caused by: java.lang.NullPointerException
at org.jclouds.json.internal.NullFilteringTypeAdapterFactories$MapTypeAdapter.read(NullFilteringTypeAdapterFactories.java:319) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.json.internal.NullFilteringTypeAdapterFactories$MapTypeAdapter.read(NullFilteringTypeAdapterFactories.java:287) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.json.internal.DeserializationConstructorAndReflectiveTypeAdapterFactory$ParameterReader.read(DeserializationConstructorAndReflectiveTypeAdapterFactory.java:275) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.json.internal.DeserializationConstructorAndReflectiveTypeAdapterFactory$DeserializeIntoParameterizedConstructor.read(DeserializationConstructorAndReflectiveTypeAdapterFactory.java:187) ~[asset-enrichment-1.0.0.jar:?]
at com.google.gson.Gson.fromJson(Gson.java:814) ~[asset-enrichment-1.0.0.jar:?]
at com.google.gson.Gson.fromJson(Gson.java:779) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.json.internal.GsonWrapper.fromJson(GsonWrapper.java:55) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:82) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:76) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:61) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:41) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.rest.internal.InvokeHttpMethod.invoke(InvokeHttpMethod.java:91) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.rest.internal.InvokeHttpMethod.apply(InvokeHttpMethod.java:74) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.rest.internal.InvokeHttpMethod.apply(InvokeHttpMethod.java:45) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.reflect.FunctionalReflection$FunctionalInvocationHandler.handleInvocation(FunctionalReflection.java:117) ~[asset-enrichment-1.0.0.jar:?]
at com.google.common.reflect.AbstractInvocationHandler.invoke(AbstractInvocationHandler.java:84) ~[asset-enrichment-1.0.0.jar:?]
at com.sun.proxy.$Proxy85.getObject(Unknown Source) ~[?:?]
at org.jclouds.googlecloudstorage.blobstore.GoogleCloudStorageBlobStore.getBlob(GoogleCloudStorageBlobStore.java:246) ~[asset-enrichment-1.0.0.jar:?]
at org.jclouds.blobstore.internal.BaseBlobStore.getBlob(BaseBlobStore.java:217) ~[asset-enrichment-1.0.0.jar:?]
at jdk.internal.reflect.GeneratedMethodAccessor425.invoke(Unknown Source) ~[?:?]
at jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(Unknown Source) ~[?:?]
at java.lang.reflect.Method.invoke(Unknown Source) ~[?:?]
at com.google.inject.internal.DelegatingInvocationHandler.invoke(DelegatingInvocationHandler.java:37) ~[asset-enrichment-1.0.0.jar:?]
at com.sun.proxy.$Proxy83.getBlob(Unknown Source) ~[?:?]
at org.sunbird.cloud.storage.BaseStorageService.download(BaseStorageService.scala:172) ~[asset-enrichment-1.0.0.jar:?]
... 35 more
2025-02-13 09:37:50,216 WARN org.apache.flink.runtime.taskmanager.Task ] - publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 (e3fdb34885230fe3834b243075ebfb1e) switched from RUNNING to FAILED with failure cause: org.sunbird.cloud.storage.exception.StorageServiceException: Error parsing input: null
{statusCode=200, message=OK, headers={Server=[UploadServer], ETag=[CLiVy4fZvosDEAE=], X-GUploader-UploadID=[AHMx-iEgybopprGI96kFD_1oJqsnuHqhuLLRzMrzASyDrc7DctJtgy4jZkQfYmZTGn1AJ3GD_4qqlg], Vary=[X-Origin, Origin], Date=[Thu, 13 Feb 2025 09:37:50 GMT]}, payload=[content=true, contentMetadata=[cacheControl=private, max-age=0, must-revalidate, no-transform, contentDisposition=null, contentEncoding=null, contentLanguage=null, contentLength=1210, contentMD5=null, contentType=application/json; charset=UTF-8, expires=Thu Feb 13 09:37:50 UTC 2025], written=false, isSensitive=false]}
at org.sunbird.cloud.storage.BaseStorageService.download(BaseStorageService.scala:178)
at org.sunbird.cloud.storage.BaseStorageService.download$(BaseStorageService.scala:160)
at org.sunbird.cloud.storage.service.GcloudStorageService.download(GcloudStorageService.scala:13)
at org.sunbird.job.util.CloudStorageUtil.downloadFile(CloudStorageUtil.scala:63)
at org.sunbird.job.content.publish.helpers.ExtractableMimeTypeHelper$.$anonfun$downloadAssetFiles$1(ExtractableMimeTypeHelper.scala:225)
at scala.collection.immutable.List.map(List.scala:286)
at org.sunbird.job.content.publish.helpers.ExtractableMimeTypeHelper$.downloadAssetFiles(ExtractableMimeTypeHelper.scala:198)
at org.sunbird.job.content.publish.helpers.ExtractableMimeTypeHelper$.processAssetsDownload(ExtractableMimeTypeHelper.scala:193)
at org.sunbird.job.content.publish.helpers.ExtractableMimeTypeHelper$.localizeAssets(ExtractableMimeTypeHelper.scala:189)
at org.sunbird.job.content.publish.helpers.ExtractableMimeTypeHelper$.processECMLBody(ExtractableMimeTypeHelper.scala:60)
at org.sunbird.job.content.function.ContentPublishFunction.processElement(ContentPublishFunction.scala:81)
at org.sunbird.job.content.function.ContentPublishFunction.processElement(ContentPublishFunction.scala:26)
at org.sunbird.job.BaseProcessFunction.processElement(BaseProcessFunction.scala:49)
at org.apache.flink.streaming.api.operators.ProcessOperator.processElement(ProcessOperator.java:66)
at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.pushToOperator(CopyingChainingOutput.java:71)
at org.apache.flink.streaming.runtime.tasks.CopyingChainingOutput.collect(CopyingChainingOutput.java:57)
at org.apache.flink.streaming.runtime.tasks.BroadcastingOutputCollector.collect(BroadcastingOutputCollector.java:82)
at org.apache.flink.streaming.api.operators.CountingOutput.collect(CountingOutput.java:56)
at org.apache.flink.streaming.api.operators.ProcessOperator$ContextImpl.output(ProcessOperator.java:103)
at org.sunbird.job.content.function.PublishEventRouter.processElement(PublishEventRouter.scala:39)
at org.sunbird.job.content.function.PublishEventRouter.processElement(PublishEventRouter.scala:13)
at org.sunbird.job.BaseProcessFunction.processElement(BaseProcessFunction.scala:49)
at org.apache.flink.streaming.api.operators.ProcessOperator.processElement(ProcessOperator.java:66)
at org.apache.flink.streaming.runtime.tasks.OneInputStreamTask$StreamTaskNetworkOutput.emitRecord(OneInputStreamTask.java:205)
at org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput.processElement(AbstractStreamTaskNetworkInput.java:134)
at org.apache.flink.streaming.runtime.io.AbstractStreamTaskNetworkInput.emitNext(AbstractStreamTaskNetworkInput.java:105)
at org.apache.flink.streaming.runtime.io.StreamOneInputProcessor.processInput(StreamOneInputProcessor.java:66)
at org.apache.flink.streaming.runtime.tasks.StreamTask.processInput(StreamTask.java:423)
at org.apache.flink.streaming.runtime.tasks.mailbox.MailboxProcessor.runMailboxLoop(MailboxProcessor.java:204)
at org.apache.flink.streaming.runtime.tasks.StreamTask.runMailboxLoop(StreamTask.java:684)
at org.apache.flink.streaming.runtime.tasks.StreamTask.executeInvoke(StreamTask.java:639)
at org.apache.flink.streaming.runtime.tasks.StreamTask.runWithCleanUpOnFail(StreamTask.java:650)
at org.apache.flink.streaming.runtime.tasks.StreamTask.invoke(StreamTask.java:623)
at org.apache.flink.runtime.taskmanager.Task.doRun(Task.java:779)
at org.apache.flink.runtime.taskmanager.Task.run(Task.java:566)
at java.base/java.lang.Thread.run(Unknown Source)
Caused by: org.jclouds.http.HttpResponseException: Error parsing input: null
{statusCode=200, message=OK, headers={Server=[UploadServer], ETag=[CLiVy4fZvosDEAE=], X-GUploader-UploadID=[AHMx-iEgybopprGI96kFD_1oJqsnuHqhuLLRzMrzASyDrc7DctJtgy4jZkQfYmZTGn1AJ3GD_4qqlg], Vary=[X-Origin, Origin], Date=[Thu, 13 Feb 2025 09:37:50 GMT]}, payload=[content=true, contentMetadata=[cacheControl=private, max-age=0, must-revalidate, no-transform, contentDisposition=null, contentEncoding=null, contentLanguage=null, contentLength=1210, contentMD5=null, contentType=application/json; charset=UTF-8, expires=Thu Feb 13 09:37:50 UTC 2025], written=false, isSensitive=false]}
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:67)
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:41)
at org.jclouds.rest.internal.InvokeHttpMethod.invoke(InvokeHttpMethod.java:91)
at org.jclouds.rest.internal.InvokeHttpMethod.apply(InvokeHttpMethod.java:74)
at org.jclouds.rest.internal.InvokeHttpMethod.apply(InvokeHttpMethod.java:45)
at org.jclouds.reflect.FunctionalReflection$FunctionalInvocationHandler.handleInvocation(FunctionalReflection.java:117)
at com.google.common.reflect.AbstractInvocationHandler.invoke(AbstractInvocationHandler.java:84)
at com.sun.proxy.$Proxy85.getObject(Unknown Source)
at org.jclouds.googlecloudstorage.blobstore.GoogleCloudStorageBlobStore.getBlob(GoogleCloudStorageBlobStore.java:246)
at org.jclouds.blobstore.internal.BaseBlobStore.getBlob(BaseBlobStore.java:217)
at jdk.internal.reflect.GeneratedMethodAccessor425.invoke(Unknown Source)
at java.base/jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(Unknown Source)
at java.base/java.lang.reflect.Method.invoke(Unknown Source)
at com.google.inject.internal.DelegatingInvocationHandler.invoke(DelegatingInvocationHandler.java:37)
at com.sun.proxy.$Proxy83.getBlob(Unknown Source)
at org.sunbird.cloud.storage.BaseStorageService.download(BaseStorageService.scala:172)
... 35 more
Caused by: java.lang.NullPointerException
at org.jclouds.json.internal.NullFilteringTypeAdapterFactories$MapTypeAdapter.read(NullFilteringTypeAdapterFactories.java:319)
at org.jclouds.json.internal.NullFilteringTypeAdapterFactories$MapTypeAdapter.read(NullFilteringTypeAdapterFactories.java:287)
at org.jclouds.json.internal.DeserializationConstructorAndReflectiveTypeAdapterFactory$ParameterReader.read(DeserializationConstructorAndReflectiveTypeAdapterFactory.java:275)
at org.jclouds.json.internal.DeserializationConstructorAndReflectiveTypeAdapterFactory$DeserializeIntoParameterizedConstructor.read(DeserializationConstructorAndReflectiveTypeAdapterFactory.java:187)
at com.google.gson.Gson.fromJson(Gson.java:814)
at com.google.gson.Gson.fromJson(Gson.java:779)
at org.jclouds.json.internal.GsonWrapper.fromJson(GsonWrapper.java:55)
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:82)
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:76)
at org.jclouds.http.functions.ParseJson.apply(ParseJson.java:61)
... 50 more
2025-02-13 09:37:50,216 INFO org.apache.flink.runtime.taskmanager.Task ] - Freeing task resources for publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 (e3fdb34885230fe3834b243075ebfb1e).
2025-02-13 09:37:50,219 INFO org.apache.flink.runtime.taskexecutor.TaskExecutor ] - Un-registering task and sending final execution state FAILED to JobManager for task publish-event-router -> (content-publish-process -> (Sink: Unnamed, Sink: Unnamed, Sink: Unnamed), collection-publish-process -> (Sink: Unnamed, Sink: Unnamed)) (1/1)#1 e3fdb34885230fe3834b243075ebfb1e.
2025-02-13 09:37:50,276 INFO org.apache.flink.runtime.taskmanager.Task ] - Attempting to cancel task Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46).
2025-02-13 09:37:50,277 INFO org.apache.flink.runtime.taskmanager.Task ] - Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46) switched from RUNNING to CANCELING.
2025-02-13 09:37:50,278 INFO org.apache.flink.runtime.taskmanager.Task ] - Triggering cancellation of task code Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46).
2025-02-13 09:37:50,285 INFO org.apache.flink.runtime.taskmanager.Task ] - Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46) switched from CANCELING to CANCELED.
2025-02-13 09:37:50,285 INFO org.apache.flink.runtime.taskmanager.Task ] - Freeing task resources for Source: content-publish-consumer (1/1)#1 (420106900146ba68e134b941ddcfda46).
2025-02-13 09:37:50,286 INFO org.apache.flink.runtime.taskexecutor.TaskExecutor ] - Un-registering task and sending final execution state CANCELED to JobManager for task Source: content-publish-consumer (1/1)#1 420106900146ba68e134b941ddcfda46.
`
@pallakartheekreddy kindly look into this
Beta Was this translation helpful? Give feedback.
All reactions