diff --git a/pom.xml b/pom.xml index 486dc7bc..6e796b5d 100644 --- a/pom.xml +++ b/pom.xml @@ -8,7 +8,7 @@ kafka-sink-azure-kusto jar A Kafka Connect plugin for Azure Data Explorer (Kusto) Database - 4.1.3 + 5.0.0 0.4.1 4.2.2 @@ -286,6 +286,12 @@ ${junit.version} test + + org.junit.jupiter + junit-jupiter-params + ${junit.version} + test + org.junit.jupiter junit-jupiter-engine @@ -298,6 +304,12 @@ ${avro.random.generator.version} test + + tech.allegro.schema.json2avro + converter + 0.2.15 + test + org.testcontainers testcontainers @@ -332,7 +344,7 @@ jitpack - https://jitpack.io + https://jitpack.io confluent diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriter.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriter.java index 94d5cfe2..68eeb3c0 100644 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriter.java +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriter.java @@ -1,364 +1,362 @@ -package com.microsoft.azure.kusto.kafka.connect.sink; - -import java.io.*; -import java.util.Map; -import java.util.Timer; -import java.util.TimerTask; -import java.util.concurrent.locks.ReentrantReadWriteLock; -import java.util.function.Consumer; -import java.util.function.Function; -import java.util.zip.GZIPOutputStream; - -import org.apache.commons.io.FilenameUtils; -import org.apache.kafka.connect.data.Schema; -import org.apache.kafka.connect.errors.ConnectException; -import org.apache.kafka.connect.errors.DataException; -import org.apache.kafka.connect.sink.SinkRecord; -import org.jetbrains.annotations.NotNull; -import org.jetbrains.annotations.Nullable; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import com.microsoft.azure.kusto.ingest.IngestionProperties; -import com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConfig.BehaviorOnError; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriterProvider; -import com.microsoft.azure.kusto.kafka.connect.sink.formatWriter.AvroRecordWriterProvider; -import com.microsoft.azure.kusto.kafka.connect.sink.formatWriter.ByteRecordWriterProvider; -import com.microsoft.azure.kusto.kafka.connect.sink.formatWriter.JsonRecordWriterProvider; -import com.microsoft.azure.kusto.kafka.connect.sink.formatWriter.StringRecordWriterProvider; - -/** - * This class is used to write gzipped rolling files. - * Currently supports size based rolling, where size is for *uncompressed* size, - * so final size can vary. - */ -public class FileWriter implements Closeable { - - private static final Logger log = LoggerFactory.getLogger(FileWriter.class); - private final long flushInterval; - private final IngestionProperties.DataFormat format; - SourceFile currentFile; - private Timer timer; - private final Consumer onRollCallback; - private final Function getFilePath; - private GZIPOutputStream outputStream; - private final String basePath; - private CountingOutputStream countingStream; - private final long fileThreshold; - // Lock is given from TopicPartitionWriter to lock while ingesting - private final ReentrantReadWriteLock reentrantReadWriteLock; - // Don't remove! File descriptor is kept so that the file is not deleted when stream is closed - private FileDescriptor currentFileDescriptor; - private String flushError; - private RecordWriterProvider recordWriterProvider; - private RecordWriter recordWriter; - private final BehaviorOnError behaviorOnError; - private boolean shouldWriteAvroAsBytes = false; - private boolean stopped = false; - private boolean isDlqEnabled = false; - - /** - * @param basePath - This is path to which to write the files to. - * @param fileThreshold - Max size, uncompressed bytes. - * @param onRollCallback - Callback to allow code to execute when rolling a file. Blocking code. - * @param getFilePath - Allow external resolving of file name. - * @param behaviorOnError - Either log, fail or ignore errors based on the mode. - */ - public FileWriter(String basePath, - long fileThreshold, - Consumer onRollCallback, - Function getFilePath, - long flushInterval, - ReentrantReadWriteLock reentrantLock, - IngestionProperties.DataFormat format, - BehaviorOnError behaviorOnError, - boolean isDlqEnabled) { - this.getFilePath = getFilePath; - this.basePath = basePath; - this.fileThreshold = fileThreshold; - this.onRollCallback = onRollCallback; - this.flushInterval = flushInterval; - this.behaviorOnError = behaviorOnError; - this.isDlqEnabled = isDlqEnabled; - // This is a fair lock so that we flush close to the time intervals - this.reentrantReadWriteLock = reentrantLock; - // If we failed on flush we want to throw the error from the put() flow. - flushError = null; - this.format = format; - } - - boolean isDirty() { - return this.currentFile != null && this.currentFile.rawBytes > 0; - } - - public void openFile(@Nullable Long offset) throws IOException { - SourceFile fileProps = new SourceFile(); - File folder = new File(basePath); - if (!folder.exists() && !folder.mkdirs()) { - if (!folder.exists()) { - throw new IOException(String.format("Failed to create new directory %s", folder.getPath())); - } - log.warn("Couldn't create the directory because it already exists (likely a race condition)"); - } - String filePath = getFilePath.apply(offset); - fileProps.path = filePath; - // Sanitize the file name just be sure and make sure it has the R/W permissions only - - String sanitizedFilePath = FilenameUtils.normalize(filePath); - if (sanitizedFilePath == null) { - /* - * This condition should not occur at all. The files are created in controlled manner with the names consisting DB name, table name. This does not - * permit names like "../../" or "./" etc. Still adding an additional check. - */ - String errorMessage = String.format("Exception creating local file for write." + - "File %s has a non canonical path", filePath); - throw new RuntimeException(errorMessage); - } - File file = new File(sanitizedFilePath); - boolean createFile = file.createNewFile(); // if there is a runtime exception. It gets thrown from here - if (createFile) { - /* - * Setting restricted permissions on the file. If these permissions cannot be set, then warn - We cannot fail the ingestion (Failing the ingestion - * would for not having the permission would mean that there may be data loss or unexpected scenarios.) Added this in a conditional as these - * permissions can be applied only when the file is created - * - */ - try { - boolean execResult = file.setReadable(true, true); - execResult = execResult && file.setWritable(true, true); - execResult = execResult && file.setExecutable(false, false); - if (!execResult) { - log.warn("Setting permissions creating file {} returned false." + - "The files set for ingestion can be read by other applications having access." + - "Please check security policies on the host that is preventing file permissions from being applied", - filePath); - } - } catch (Exception ex) { - // There is a likely chance of the permissions not getting set. This is set to warn - log.warn("Exception permissions creating file {} returned false." + - "The files set for ingestion can be read by other applications having access." + - "Please check security policies on the host that is preventing file permissions being applied", - filePath, ex); - - } - } - // The underlying file is closed only when the current countingStream (abstraction for size based writes) and - // the file is rolled over - FileOutputStream fos = new FileOutputStream(file); - currentFileDescriptor = fos.getFD(); - fos.getChannel().truncate(0); - fileProps.file = file; - currentFile = fileProps; - countingStream = new CountingOutputStream(new GZIPOutputStream(fos)); - outputStream = countingStream.getOutputStream(); - recordWriter = recordWriterProvider.getRecordWriter(currentFile.path, countingStream); - } - - void rotate(@Nullable Long offset) throws IOException, DataException { - finishFile(true); - openFile(offset); - } - - void finishFile(boolean delete) throws IOException, DataException { - if (isDirty()) { - recordWriter.commit(); - // Since we are using GZIP compression, finish the file. Close is invoked only when this flush finishes - // and then the file is finished in ingest - // This is called when there is a time or a size limit reached. The file is then reset/rolled and then a - // new file is created for processing - outputStream.finish(); - // It could be we were waiting on the lock when task suddenly stops and we should not ingest anymore - if (stopped) { - return; - } - try { - onRollCallback.accept(currentFile); - } catch (ConnectException e) { - /* - * Swallow the exception and continue to process subsequent records when behavior.on.error is not set to fail mode. Also, throwing/logging the - * exception with just a message to avoid polluting logs with duplicate trace. - */ - handleErrors("Failed to write records to KustoDB.", e); - } - if (delete) { - dumpFile(); - } - } else { - // The stream is closed only when there are non-empty files for ingestion. Note that this closes the - // FileOutputStream as well - outputStream.close(); - currentFile = null; - } - } - - private void handleErrors(String message, Exception e) { - if (KustoSinkConfig.BehaviorOnError.FAIL == behaviorOnError) { - throw new ConnectException(message, e); - } else if (KustoSinkConfig.BehaviorOnError.LOG == behaviorOnError) { - log.error("{}", message, e); - } else { - log.debug("{}", message, e); - } - } - - private void dumpFile() throws IOException { - SourceFile temp = currentFile; - currentFile = null; - if (temp != null) { - countingStream.close(); - currentFileDescriptor = null; - boolean deleted = temp.file.delete(); - if (!deleted) { - log.warn("Couldn't delete temporary file. File exists: {}", temp.file.exists()); - } - } - } - - public synchronized void rollback() throws IOException { - if (countingStream != null) { - countingStream.close(); - if (currentFile != null && currentFile.file != null) { - dumpFile(); - } - } - } - - @Override - public synchronized void close() throws IOException { - stop(); - } - - public synchronized void stop() throws DataException { - stopped = true; - if (timer != null) { - Timer temp = timer; - timer = null; - temp.cancel(); - } - } - - // Set shouldDestroyTimer to true if the current running task should be cancelled - private void resetFlushTimer(boolean shouldDestroyTimer) { - if (flushInterval > 0) { - if (shouldDestroyTimer) { - if (timer != null) { - timer.cancel(); - } - timer = new Timer(true); - } - TimerTask t = new TimerTask() { - @Override - public void run() { - flushByTimeImpl(); - } - }; - if (timer != null) { - timer.schedule(t, flushInterval); - } - } - } - - void flushByTimeImpl() { - // Flush time interval gets the write lock so that it won't starve - try (AutoCloseableLock ignored = new AutoCloseableLock(reentrantReadWriteLock.writeLock())) { - if (stopped) { - return; - } - // Lock before the check so that if a writing process just flushed this won't ingest empty files - if (isDirty()) { - finishFile(true); - } - resetFlushTimer(false); - } catch (Exception e) { - String fileName = currentFile == null ? "[no file created yet]" : currentFile.file.getName(); - long currentSize = currentFile == null ? 0 : currentFile.rawBytes; - flushError = String.format("Error in flushByTime. Current file: %s, size: %d. ", fileName, currentSize); - log.error(flushError, e); - } - } - - public void writeData(SinkRecord sinkRecord) throws IOException, DataException { - if (flushError != null) { - throw new ConnectException(flushError); - } - if (sinkRecord == null) - return; - if (recordWriterProvider == null) { - initializeRecordWriter(sinkRecord); - } - if (currentFile == null) { - openFile(sinkRecord.kafkaOffset()); - resetFlushTimer(true); - } - recordWriter.write(sinkRecord); - if (this.isDlqEnabled) { - currentFile.records.add(sinkRecord); - } - currentFile.rawBytes = countingStream.numBytes; - currentFile.numRecords++; - if (this.flushInterval == 0 || currentFile.rawBytes > fileThreshold || shouldWriteAvroAsBytes) { - rotate(sinkRecord.kafkaOffset()); - resetFlushTimer(true); - } - } - - public void initializeRecordWriter(SinkRecord sinkRecord) { - if (sinkRecord.value() instanceof Map) { - recordWriterProvider = new JsonRecordWriterProvider(); - } else if ((sinkRecord.valueSchema() != null) && (sinkRecord.valueSchema().type() == Schema.Type.STRUCT)) { - if (format.equals(IngestionProperties.DataFormat.JSON) || format.equals(IngestionProperties.DataFormat.MULTIJSON)) { - recordWriterProvider = new JsonRecordWriterProvider(); - } else if (format.equals(IngestionProperties.DataFormat.AVRO)) { - recordWriterProvider = new AvroRecordWriterProvider(); - } else { - throw new ConnectException(String.format("Invalid Kusto table mapping, Kafka records of type " - + "Avro and JSON can only be ingested to Kusto table having Avro or JSON mapping. " - + "Currently, it is of type %s.", format)); - } - } else if ((sinkRecord.valueSchema() == null) || (sinkRecord.valueSchema().type() == Schema.Type.STRING)) { - recordWriterProvider = new StringRecordWriterProvider(); - } else if ((sinkRecord.valueSchema() != null) && (sinkRecord.valueSchema().type() == Schema.Type.BYTES)) { - recordWriterProvider = new ByteRecordWriterProvider(); - if (format.equals(IngestionProperties.DataFormat.AVRO)) { - shouldWriteAvroAsBytes = true; - } - } else { - throw new ConnectException(String.format( - "Invalid Kafka record format, connector does not support %s format. This connector supports Avro, Json with schema, Json without schema, Byte, String format. ", - sinkRecord.valueSchema().type())); - } - } - - private class CountingOutputStream extends FilterOutputStream { - private long numBytes = 0; - private final GZIPOutputStream outputStream; - - CountingOutputStream(GZIPOutputStream out) { - super(out); - this.outputStream = out; - } - - @Override - public void write(int b) throws IOException { - out.write(b); - this.numBytes++; - } - - @Override - public void write(byte @NotNull [] b) throws IOException { - out.write(b); - this.numBytes += b.length; - } - - @Override - public void write(byte @NotNull [] b, int off, int len) throws IOException { - out.write(b, off, len); - this.numBytes += len; - } - - public GZIPOutputStream getOutputStream() { - return this.outputStream; - } - } -} +package com.microsoft.azure.kusto.kafka.connect.sink; + +import java.io.*; +import java.util.Map; +import java.util.Timer; +import java.util.TimerTask; +import java.util.concurrent.locks.ReentrantReadWriteLock; +import java.util.function.Consumer; +import java.util.function.Function; +import java.util.zip.GZIPOutputStream; + +import org.apache.commons.io.FilenameUtils; +import org.apache.kafka.connect.data.Schema; +import org.apache.kafka.connect.errors.ConnectException; +import org.apache.kafka.connect.errors.DataException; +import org.apache.kafka.connect.sink.SinkRecord; +import org.jetbrains.annotations.NotNull; +import org.jetbrains.annotations.Nullable; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; + +import com.microsoft.azure.kusto.ingest.IngestionProperties; +import com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConfig.BehaviorOnError; +import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; +import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriterProvider; +import com.microsoft.azure.kusto.kafka.connect.sink.formatwriter.KustoRecordWriterProvider; + +/** + * This class is used to write gzipped rolling files. + * Currently, supports size based rolling, where size is for *uncompressed* size, + * so final size can vary. + */ +public class FileWriter implements Closeable { + + private static final Logger log = LoggerFactory.getLogger(FileWriter.class); + private final long flushInterval; + private final IngestionProperties.DataFormat format; + private final Consumer onRollCallback; + private final Function getFilePath; + private final String basePath; + private final long fileThreshold; + // Lock is given from TopicPartitionWriter to lock while ingesting + private final ReentrantReadWriteLock reentrantReadWriteLock; + private final BehaviorOnError behaviorOnError; + SourceFile currentFile; + private Timer timer; + private GZIPOutputStream outputStream; + private CountingOutputStream countingStream; + // Don't remove! File descriptor is kept so that the file is not deleted when stream is closed + private FileDescriptor currentFileDescriptor; + private String flushError; + private RecordWriterProvider recordWriterProvider; + private RecordWriter recordWriter; + private boolean shouldWriteAvroAsBytes = false; + private boolean stopped = false; + private boolean isDlqEnabled = false; + + /** + * @param basePath - This is path to which to write the files to. + * @param fileThreshold - Max size, uncompressed bytes. + * @param onRollCallback - Callback to allow code to execute when rolling a file. Blocking code. + * @param getFilePath - Allow external resolving of file name. + * @param behaviorOnError - Either log, fail or ignore errors based on the mode. + */ + public FileWriter(String basePath, + long fileThreshold, + Consumer onRollCallback, + Function getFilePath, + long flushInterval, + ReentrantReadWriteLock reentrantLock, + IngestionProperties.DataFormat format, + BehaviorOnError behaviorOnError, + boolean isDlqEnabled) { + this.getFilePath = getFilePath; + this.basePath = basePath; + this.fileThreshold = fileThreshold; + this.onRollCallback = onRollCallback; + this.flushInterval = flushInterval; + this.behaviorOnError = behaviorOnError; + this.isDlqEnabled = isDlqEnabled; + // This is a fair lock so that we flush close to the time intervals + this.reentrantReadWriteLock = reentrantLock; + // If we failed on flush we want to throw the error from the put() flow. + flushError = null; + this.format = format; + } + + boolean isDirty() { + return this.currentFile != null && this.currentFile.rawBytes > 0; + } + + public void openFile(@Nullable Long offset) throws IOException { + SourceFile fileProps = new SourceFile(); + File folder = new File(basePath); + if (!folder.exists() && !folder.mkdirs()) { + if (!folder.exists()) { + throw new IOException(String.format("Failed to create new directory %s", folder.getPath())); + } + log.warn("Couldn't create the directory because it already exists (likely a race condition)"); + } + String filePath = getFilePath.apply(offset); + fileProps.path = filePath; + // Sanitize the file name just be sure and make sure it has the R/W permissions only + + String sanitizedFilePath = FilenameUtils.normalize(filePath); + if (sanitizedFilePath == null) { + /* + * This condition should not occur at all. The files are created in controlled manner with the names consisting DB name, table name. This does not + * permit names like "../../" or "./" etc. Still adding an additional check. + */ + String errorMessage = String.format("Exception creating local file for write." + + "File %s has a non canonical path", filePath); + throw new RuntimeException(errorMessage); + } + File file = new File(sanitizedFilePath); + boolean createFile = file.createNewFile(); // if there is a runtime exception. It gets thrown from here + if (createFile) { + /* + * Setting restricted permissions on the file. If these permissions cannot be set, then warn - We cannot fail the ingestion (Failing the ingestion + * would for not having the permission would mean that there may be data loss or unexpected scenarios.) Added this in a conditional as these + * permissions can be applied only when the file is created + * + */ + try { + boolean execResult = file.setReadable(true, true); + execResult = execResult && file.setWritable(true, true); + execResult = execResult && file.setExecutable(false, false); + if (!execResult) { + log.warn("Setting permissions creating file {} returned false." + + "The files set for ingestion can be read by other applications having access." + + "Please check security policies on the host that is preventing file permissions from being applied", + filePath); + } + } catch (Exception ex) { + // There is a likely chance of the permissions not getting set. This is set to warn + log.warn("Exception permissions creating file {} returned false." + + "The files set for ingestion can be read by other applications having access." + + "Please check security policies on the host that is preventing file permissions being applied", + filePath, ex); + + } + } + // The underlying file is closed only when the current countingStream (abstraction for size based writes) and + // the file is rolled over + FileOutputStream fos = new FileOutputStream(file); + currentFileDescriptor = fos.getFD(); + fos.getChannel().truncate(0); + fileProps.file = file; + currentFile = fileProps; + countingStream = new CountingOutputStream(new GZIPOutputStream(fos)); + outputStream = countingStream.getOutputStream(); + log.debug("Opened new file for writing: {}", fileProps.file); + recordWriter = recordWriterProvider.getRecordWriter(currentFile.path, countingStream); + } + + void rotate(@Nullable Long offset) throws IOException, DataException { + finishFile(true); + openFile(offset); + } + + void finishFile(boolean delete) throws IOException, DataException { + if (isDirty()) { + recordWriter.commit(); + // Since we are using GZIP compression, finish the file. Close is invoked only when this flush finishes + // and then the file is finished in ingest + // This is called when there is a time or a size limit reached. The file is then reset/rolled and then a + // new file is created for processing + outputStream.finish(); + // It could be we were waiting on the lock when task suddenly stops and we should not ingest anymore + if (stopped) { + return; + } + try { + onRollCallback.accept(currentFile); + } catch (ConnectException e) { + /* + * Swallow the exception and continue to process subsequent records when behavior.on.error is not set to fail mode. Also, throwing/logging the + * exception with just a message to avoid polluting logs with duplicate trace. + */ + handleErrors("Failed to write records to KustoDB.", e); + } + if (delete) { + dumpFile(); + } + } else { + // The stream is closed only when there are non-empty files for ingestion. Note that this closes the + // FileOutputStream as well + outputStream.close(); + currentFile = null; + } + } + + private void handleErrors(String message, Exception e) { + if (KustoSinkConfig.BehaviorOnError.FAIL == behaviorOnError) { + throw new ConnectException(message, e); + } else if (KustoSinkConfig.BehaviorOnError.LOG == behaviorOnError) { + log.error("{}", message, e); + } else { + log.debug("{}", message, e); + } + } + + private void dumpFile() throws IOException { + SourceFile temp = currentFile; + currentFile = null; + if (temp != null) { + countingStream.close(); + currentFileDescriptor = null; + boolean deleted = temp.file.delete(); + if (!deleted) { + log.warn("Couldn't delete temporary file. File exists: {}", temp.file.exists()); + } + } + } + + public synchronized void rollback() throws IOException { + if (countingStream != null) { + countingStream.close(); + if (currentFile != null && currentFile.file != null) { + dumpFile(); + } + } + } + + @Override + public synchronized void close() throws IOException { + stop(); + } + + public synchronized void stop() throws DataException { + stopped = true; + if (timer != null) { + Timer temp = timer; + timer = null; + temp.cancel(); + } + } + + // Set shouldDestroyTimer to true if the current running task should be cancelled + private void resetFlushTimer(boolean shouldDestroyTimer) { + if (flushInterval > 0) { + if (shouldDestroyTimer) { + if (timer != null) { + timer.cancel(); + } + timer = new Timer(true); + } + TimerTask t = new TimerTask() { + @Override + public void run() { + flushByTimeImpl(); + } + }; + if (timer != null) { + timer.schedule(t, flushInterval); + } + } + } + + void flushByTimeImpl() { + // Flush time interval gets the write lock so that it won't starve + try (AutoCloseableLock ignored = new AutoCloseableLock(reentrantReadWriteLock.writeLock())) { + if (stopped) { + return; + } + // Lock before the check so that if a writing process just flushed this won't ingest empty files + if (isDirty()) { + finishFile(true); + } + resetFlushTimer(false); + } catch (Exception e) { + String fileName = currentFile == null ? "[no file created yet]" : currentFile.file.getName(); + long currentSize = currentFile == null ? 0 : currentFile.rawBytes; + flushError = String.format("Error in flushByTime. Current file: %s, size: %d. ", fileName, currentSize); + log.error(flushError, e); + } + } + + public void writeData(SinkRecord sinkRecord) throws IOException, DataException { + if (flushError != null) { + throw new ConnectException(flushError); + } + if (sinkRecord == null) + return; + if (recordWriterProvider == null) { + initializeRecordWriter(sinkRecord); + } + if (currentFile == null) { + openFile(sinkRecord.kafkaOffset()); + resetFlushTimer(true); + } + recordWriter.write(sinkRecord, this.format); + if (this.isDlqEnabled) { + currentFile.records.add(sinkRecord); + } + currentFile.rawBytes = countingStream.numBytes; + currentFile.numRecords++; + if (this.flushInterval == 0 || currentFile.rawBytes > fileThreshold || shouldWriteAvroAsBytes) { + rotate(sinkRecord.kafkaOffset()); + resetFlushTimer(true); + } + } + + public void initializeRecordWriter(@NotNull SinkRecord sinkRecord) { + if (sinkRecord.value() instanceof Map) { + recordWriterProvider = new KustoRecordWriterProvider(); + } else if ((sinkRecord.valueSchema() != null) && (sinkRecord.valueSchema().type() == Schema.Type.STRUCT)) { + if (format.equals(IngestionProperties.DataFormat.JSON) || format.equals(IngestionProperties.DataFormat.MULTIJSON)) { + recordWriterProvider = new KustoRecordWriterProvider(); + } else if (format.equals(IngestionProperties.DataFormat.AVRO)) { + recordWriterProvider = new KustoRecordWriterProvider(); + } else { + throw new ConnectException(String.format("Invalid Kusto table mapping, Kafka records of type " + + "Avro and JSON can only be ingested to Kusto table having Avro or JSON mapping. " + + "Currently, it is of type %s.", format)); + } + } else if ((sinkRecord.valueSchema() == null) || (sinkRecord.valueSchema().type() == Schema.Type.STRING)) { + recordWriterProvider = new KustoRecordWriterProvider(); + } else if ((sinkRecord.valueSchema() != null) && (sinkRecord.valueSchema().type() == Schema.Type.BYTES)) { + recordWriterProvider = new KustoRecordWriterProvider(); + if (format.equals(IngestionProperties.DataFormat.AVRO)) { + shouldWriteAvroAsBytes = true; + } + } else { + throw new ConnectException(String.format( + "Invalid Kafka record format, connector does not support %s format. This connector supports Avro, Json with schema, Json without schema, Byte, String format. ", + sinkRecord.valueSchema().type())); + } + } + + private class CountingOutputStream extends FilterOutputStream { + private final GZIPOutputStream outputStream; + private long numBytes = 0; + + CountingOutputStream(GZIPOutputStream out) { + super(out); + this.outputStream = out; + } + + @Override + public void write(int b) throws IOException { + out.write(b); + this.numBytes++; + } + + @Override + public void write(byte @NotNull [] b) throws IOException { + out.write(b); + this.numBytes += b.length; + } + + @Override + public void write(byte @NotNull [] b, int off, int len) throws IOException { + out.write(b, off, len); + this.numBytes += len; + } + + public GZIPOutputStream getOutputStream() { + return this.outputStream; + } + } +} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConfig.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConfig.java index 067eedf9..a4a673b5 100644 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConfig.java +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConfig.java @@ -374,7 +374,6 @@ public String getAuthAppId() { return this.getString(KUSTO_AUTH_APPID_CONF); } - public String getAuthAppKey() { return this.getPassword(KUSTO_AUTH_APPKEY_CONF).value(); } diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTask.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTask.java index 43c32542..fa7eefa4 100644 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTask.java +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTask.java @@ -129,7 +129,7 @@ private static boolean isStreamingEnabled(@NotNull KustoSinkConfig config) throw return kcsb; } - public static Client createKustoEngineClient(KustoSinkConfig config) { + public static @NotNull Client createKustoEngineClient(KustoSinkConfig config) { try { return ClientFactory.createClient(createKustoEngineConnectionString(config, config.getKustoEngineUrl())); } catch (Exception e) { @@ -142,30 +142,23 @@ public static Map getTopicsToIngestionProps(Ku try { TopicToTableMapping[] mappings = config.getTopicToTableMapping(); - for (TopicToTableMapping mapping : mappings) { IngestionProperties props = new IngestionProperties(mapping.getDb(), mapping.getTable()); String format = mapping.getFormat(); if (StringUtils.isNotEmpty(format)) { - if (isDataFormatAnyTypeOfJson(format)) { - props.setDataFormat(IngestionProperties.DataFormat.MULTIJSON); - } else { - props.setDataFormat(format); - } + props.setDataFormat(format); + // if (isDataFormatAnyTypeOfJson(format)) { + // props.setDataFormat(IngestionProperties.DataFormat.MULTIJSON); + // } else { + // props.setDataFormat(format); + // } } String mappingRef = mapping.getMapping(); - if (StringUtils.isNotEmpty(mappingRef) && format != null) { - if (isDataFormatAnyTypeOfJson(format)) { - props.setIngestionMapping(mappingRef, IngestionMapping.IngestionMappingKind.JSON); - } else if (format.equalsIgnoreCase(IngestionProperties.DataFormat.AVRO.toString())) { - props.setIngestionMapping(mappingRef, IngestionMapping.IngestionMappingKind.AVRO); - } else if (format.equalsIgnoreCase(IngestionProperties.DataFormat.APACHEAVRO.toString())) { - props.setIngestionMapping(mappingRef, IngestionMapping.IngestionMappingKind.APACHEAVRO); - } else { - props.setIngestionMapping(mappingRef, IngestionMapping.IngestionMappingKind.CSV); - } + if (StringUtils.isNotEmpty(mappingRef) && StringUtils.isNotEmpty(format)) { + props.setIngestionMapping(mappingRef, + IngestionMapping.IngestionMappingKind.valueOf(format.toUpperCase(Locale.ROOT))); } TopicIngestionProperties topicIngestionProperties = new TopicIngestionProperties(); topicIngestionProperties.ingestionProperties = props; @@ -177,8 +170,7 @@ public static Map getTopicsToIngestionProps(Ku throw new ConfigException("Error while parsing kusto ingestion properties.", ex); } } - - private static boolean isDataFormatAnyTypeOfJson(String format) { + private static boolean isDataFormatAnyTypeOfJson(@NotNull String format) { return format.equalsIgnoreCase(IngestionProperties.DataFormat.JSON.name()) || format.equalsIgnoreCase(IngestionProperties.DataFormat.SINGLEJSON.name()) || format.equalsIgnoreCase(IngestionProperties.DataFormat.MULTIJSON.name()); @@ -200,9 +192,6 @@ private static void validateTableAccess(Client engineClient, TopicToTableMapping String format = mapping.getFormat(); String mappingName = mapping.getMapping(); boolean streamingEnabled = mapping.isStreaming(); - if (isDataFormatAnyTypeOfJson(format)) { - format = IngestionProperties.DataFormat.JSON.name(); - } boolean hasAccess = false; boolean shouldCheckStreaming = streamingEnabled; @@ -307,7 +296,7 @@ public TopicIngestionProperties getIngestionProps(String topic) { return topicsToIngestionProps.get(topic); } - void validateTableMappings(KustoSinkConfig config) { + void validateTableMappings(@NotNull KustoSinkConfig config) { List databaseTableErrorList = new ArrayList<>(); List accessErrorList = new ArrayList<>(); boolean enableTableValidation = config.getEnableTableValidation(); @@ -342,7 +331,7 @@ void validateTableMappings(KustoSinkConfig config) { } } - private boolean isIngestorRole(TopicToTableMapping testMapping, Client engineClient) { + private boolean isIngestorRole(@NotNull TopicToTableMapping testMapping, @NotNull Client engineClient) { try { engineClient.execute(testMapping.getDb(), String.format(FETCH_TABLE_COMMAND, testMapping.getTable()), validateOnlyClientRequestProperties); } catch (DataServiceException | DataClientException err) { @@ -379,7 +368,7 @@ public void open(Collection partitions) { } @Override - public void close(Collection partitions) { + public void close(@NotNull Collection partitions) { log.warn("Closing writers in KustoSinkTask"); CountDownLatch countDownLatch = new CountDownLatch(partitions.size()); // First stop so that no more ingestions trigger from timer flushes @@ -404,7 +393,6 @@ public void close(Collection partitions) { public void start(Map props) { config = new KustoSinkConfig(props); String url = config.getKustoIngestUrl(); - validateTableMappings(config); if (config.isDlqEnabled()) { isDlqEnabled = true; @@ -417,18 +405,14 @@ public void start(Map props) { } catch (Exception e) { throw new ConnectException("Failed to initialize producer for miscellaneous dead-letter queue", e); } - } else { dlqProducer = null; isDlqEnabled = false; dlqTopicName = null; } - topicsToIngestionProps = getTopicsToIngestionProps(config); - // this should be read properly from settings createKustoIngestClient(config); - log.info("Started KustoSinkTask with target cluster: ({}), source topics: ({})", url, topicsToIngestionProps.keySet()); // Adding this check to make code testable @@ -458,13 +442,12 @@ public void stop() { } @Override - public void put(Collection records) { + public void put(@NotNull Collection records) { SinkRecord lastRecord = null; for (SinkRecord sinkRecord : records) { lastRecord = sinkRecord; TopicPartition tp = new TopicPartition(sinkRecord.topic(), sinkRecord.kafkaPartition()); TopicPartitionWriter writer = writers.get(tp); - if (writer == null) { NotFoundException e = new NotFoundException(String.format("Received a record without " + "a mapped writer for topic:partition(%s:%d), dropping record.", tp.topic(), tp.partition())); @@ -497,7 +480,6 @@ public Map preCommit( "verify your `topics` and `kusto.tables.topics.mapping` configurations"); } Long lastCommittedOffset = writers.get(tp).lastCommittedOffset; - if (lastCommittedOffset != null) { long offset = lastCommittedOffset + 1L; log.debug("Forwarding to framework request to commit offset: {} for {} while the offset is {}", offset, @@ -505,7 +487,6 @@ public Map preCommit( offsetsToCommit.put(tp, new OffsetAndMetadata(offset)); } } - return offsetsToCommit; } diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriter.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriter.java index 1493c718..38db7500 100644 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriter.java +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriter.java @@ -19,12 +19,15 @@ import org.apache.kafka.connect.errors.ConnectException; import org.apache.kafka.connect.errors.DataException; import org.apache.kafka.connect.sink.SinkRecord; +import org.jetbrains.annotations.NotNull; import org.jetbrains.annotations.Nullable; import org.slf4j.Logger; import org.slf4j.LoggerFactory; import com.microsoft.azure.kusto.data.exceptions.KustoDataExceptionBase; import com.microsoft.azure.kusto.ingest.IngestClient; +import com.microsoft.azure.kusto.ingest.IngestionMapping; +import com.microsoft.azure.kusto.ingest.IngestionProperties; import com.microsoft.azure.kusto.ingest.ManagedStreamingIngestClient; import com.microsoft.azure.kusto.ingest.exceptions.IngestionClientException; import com.microsoft.azure.kusto.ingest.exceptions.IngestionServiceException; @@ -33,13 +36,16 @@ import com.microsoft.azure.kusto.ingest.result.IngestionStatusResult; import com.microsoft.azure.kusto.ingest.source.FileSourceInfo; import com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConfig.BehaviorOnError; +import com.microsoft.azure.kusto.kafka.connect.sink.formatwriter.FormatWriterHelper; + +import static com.microsoft.azure.kusto.ingest.IngestionProperties.DataFormat.*; public class TopicPartitionWriter { private static final Logger log = LoggerFactory.getLogger(TopicPartitionWriter.class); private static final String COMPRESSION_EXTENSION = ".gz"; private static final String FILE_EXCEPTION_MESSAGE = "Failed to create file or write record into file for ingestion."; - + private final FormatWriterHelper formatWriterHelper = FormatWriterHelper.getInstance(); private final TopicPartition tp; private final IngestClient client; private final TopicIngestionProperties ingestionProps; @@ -52,10 +58,10 @@ public class TopicPartitionWriter { private final String dlqTopicName; private final Producer dlqProducer; private final BehaviorOnError behaviorOnError; + private final ReentrantReadWriteLock reentrantReadWriteLock; FileWriter fileWriter; long currentOffset; Long lastCommittedOffset; - private final ReentrantReadWriteLock reentrantReadWriteLock; TopicPartitionWriter(TopicPartition tp, IngestClient client, TopicIngestionProperties ingestionProps, KustoSinkConfig config, boolean isDlqEnabled, String dlqTopicName, Producer dlqProducer) { @@ -75,15 +81,14 @@ public class TopicPartitionWriter { this.dlqProducer = dlqProducer; } - static String getTempDirectoryName(String tempDirPath) { + static @NotNull String getTempDirectoryName(String tempDirPath) { String tempDir = String.format("kusto-sink-connector-%s", UUID.randomUUID()); Path path = Paths.get(tempDirPath, tempDir).toAbsolutePath(); return path.toString(); } - public void handleRollFile(SourceFile fileDescriptor) { + public void handleRollFile(@NotNull SourceFile fileDescriptor) { FileSourceInfo fileSourceInfo = new FileSourceInfo(fileDescriptor.path, fileDescriptor.rawBytes); - /* * Since retries can be for a longer duration the Kafka Consumer may leave the group. This will result in a new Consumer reading records from the last * committed offset leading to duplication of records in KustoDB. Also, if the error persists, it might also result in duplicate records being written @@ -92,7 +97,7 @@ public void handleRollFile(SourceFile fileDescriptor) { */ for (int retryAttempts = 0; true; retryAttempts++) { try { - IngestionResult ingestionResult = client.ingestFromFile(fileSourceInfo, ingestionProps.ingestionProperties); + IngestionResult ingestionResult = client.ingestFromFile(fileSourceInfo, updateIngestionPropertiesWithTargetFormat()); if (ingestionProps.streaming && ingestionResult instanceof IngestionStatusResult) { // If IngestionStatusResult returned then the ingestion status is from streaming ingest IngestionStatus ingestionStatus = ingestionResult.getIngestionStatusCollection().get(0); @@ -123,14 +128,22 @@ public void handleRollFile(SourceFile fileDescriptor) { } // TODO : improve handling of specific transient exceptions once the client supports them. // retrying transient exceptions + log.error("IngestionServiceException when ingesting data into KustoDB, file: {}, database: {}, table: {}, operationId: {}", + fileDescriptor.path, ingestionProps.ingestionProperties.getDatabaseName(), + ingestionProps.ingestionProperties.getTableName(), + ingestionProps.ingestionProperties.getIngestionMapping().getIngestionMappingReference(),exception); backOffForRemainingAttempts(retryAttempts, exception, fileDescriptor); } catch (IngestionClientException | URISyntaxException exception) { + log.error("IngestionClientException when ingesting data into KustoDB, file: {}, database: {}, table: {}, operationId: {}", + fileDescriptor.path, ingestionProps.ingestionProperties.getDatabaseName(), + ingestionProps.ingestionProperties.getTableName(), + ingestionProps.ingestionProperties.getIngestionMapping().getIngestionMappingReference(),exception); throw new ConnectException(exception); } } } - private boolean hasStreamingSucceeded(IngestionStatus status) { + private boolean hasStreamingSucceeded(@NotNull IngestionStatus status) { switch (status.status) { case Succeeded: case Queued: @@ -157,32 +170,38 @@ private boolean hasStreamingSucceeded(IngestionStatus status) { return false; } - private void backOffForRemainingAttempts(int retryAttempts, Exception exception, SourceFile fileDescriptor) { + private void backOffForRemainingAttempts(int retryAttempts, Exception exception, @NotNull SourceFile fileDescriptor) { if (retryAttempts < maxRetryAttempts) { // RetryUtil can be deleted if exponential backOff is not required, currently using constant backOff. // long sleepTimeMs = RetryUtil.computeExponentialBackOffWithJitter(retryAttempts, TimeUnit.SECONDS.toMillis(5)); long sleepTimeMs = retryBackOffTime; - log.error("Failed to ingest records into Kusto, backing off and retrying ingesting records after {} milliseconds.", sleepTimeMs); + if(exception!=null) { + log.error("Failed to ingest records into Kusto, backing off and retrying ingesting records " + + "after {} milliseconds.", sleepTimeMs, exception); + } try { TimeUnit.MILLISECONDS.sleep(sleepTimeMs); } catch (InterruptedException interruptedErr) { if (isDlqEnabled && behaviorOnError != BehaviorOnError.FAIL) { - log.warn("Writing {} failed records to miscellaneous dead-letter queue topic={}", fileDescriptor.records.size(), dlqTopicName); + log.warn("InterruptedException:: Writing {} failed records to miscellaneous dead-letter queue topic={}", + fileDescriptor.records.size(), dlqTopicName); fileDescriptor.records.forEach(this::sendFailedRecordToDlq); } - throw new ConnectException(String.format("Retrying ingesting records into KustoDB was interrupted after retryAttempts=%s", retryAttempts + 1), + throw new ConnectException(String.format("Retrying ingesting records into KustoDB was interrupted " + + "after retryAttempts=%s", retryAttempts + 1), exception); } } else { if (isDlqEnabled && behaviorOnError != BehaviorOnError.FAIL) { - log.warn("Writing {} failed records to miscellaneous dead-letter queue topic={}", fileDescriptor.records.size(), dlqTopicName); + log.warn(String.format("Retries exhausted, writing {%s} failed records to miscellaneous dead-letter queue topic={%s}", + fileDescriptor.records.size(), dlqTopicName)); fileDescriptor.records.forEach(this::sendFailedRecordToDlq); } throw new ConnectException("Retry attempts exhausted, failed to ingest records into KustoDB.", exception); } } - public void sendFailedRecordToDlq(SinkRecord sinkRecord) { + public void sendFailedRecordToDlq(@NotNull SinkRecord sinkRecord) { byte[] recordKey = String.format("Failed to write sinkRecord to KustoDB with the following kafka coordinates, " + "topic=%s, partition=%s, offset=%s.", sinkRecord.topic(), @@ -274,4 +293,24 @@ void close() { void stop() { fileWriter.stop(); } + + private @NotNull IngestionProperties updateIngestionPropertiesWithTargetFormat() { + IngestionProperties updatedIngestionProperties = new IngestionProperties(this.ingestionProps.ingestionProperties); + IngestionProperties.DataFormat sourceFormat = ingestionProps.ingestionProperties.getDataFormat(); + if (formatWriterHelper.isSchemaFormat(sourceFormat)) { + log.debug("Incoming dataformat {}, setting target format to MULTIJSON", sourceFormat); + updatedIngestionProperties.setDataFormat(MULTIJSON); + } else { + updatedIngestionProperties.setDataFormat(ingestionProps.ingestionProperties.getDataFormat()); + } + // Just to make it clear , split the conditional + if (formatWriterHelper.isSchemaFormat(sourceFormat)) { + IngestionMapping mappingReference = ingestionProps.ingestionProperties.getIngestionMapping(); + if (mappingReference != null && StringUtils.isNotEmpty(mappingReference.getIngestionMappingReference())) { + String ingestionMappingReferenceName = mappingReference.getIngestionMappingReference(); + updatedIngestionProperties.setIngestionMapping(ingestionMappingReferenceName, IngestionMapping.IngestionMappingKind.JSON); + } + } + return updatedIngestionProperties; + } } diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/format/RecordWriter.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/format/RecordWriter.java index de033af9..cca404a3 100644 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/format/RecordWriter.java +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/format/RecordWriter.java @@ -1,26 +1,28 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.format; - -import java.io.Closeable; -import java.io.IOException; - -import org.apache.kafka.connect.sink.SinkRecord; - -public interface RecordWriter extends Closeable { - /** - * Write a record to storage. - * - * @param record the record to persist. - */ - void write(SinkRecord record) throws IOException; - - /** - * Close this writer. - */ - void close(); - - /** - * Flush writer's data and commit the records in Kafka. Optionally, this operation might also - * close the writer. - */ - void commit(); -} +package com.microsoft.azure.kusto.kafka.connect.sink.format; + +import java.io.Closeable; +import java.io.IOException; + +import org.apache.kafka.connect.sink.SinkRecord; + +import com.microsoft.azure.kusto.ingest.IngestionProperties; + +public interface RecordWriter extends Closeable { + /** + * Write a record to storage. + * + * @param record the record to persist. + */ + void write(SinkRecord record, IngestionProperties.DataFormat dataFormat) throws IOException; + + /** + * Close this writer. + */ + void close(); + + /** + * Flush writer's data and commit the records in Kafka. Optionally, this operation might also + * close the writer. + */ + void commit(); +} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/AvroRecordWriterProvider.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/AvroRecordWriterProvider.java deleted file mode 100644 index ca74e83e..00000000 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/AvroRecordWriterProvider.java +++ /dev/null @@ -1,73 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.IOException; -import java.io.OutputStream; - -import org.apache.avro.file.DataFileWriter; -import org.apache.avro.generic.GenericDatumWriter; -import org.apache.kafka.connect.data.Schema; -import org.apache.kafka.connect.errors.ConnectException; -import org.apache.kafka.connect.errors.DataException; -import org.apache.kafka.connect.sink.SinkRecord; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriterProvider; - -import io.confluent.connect.avro.AvroData; -import io.confluent.kafka.serializers.NonRecordContainer; - -public class AvroRecordWriterProvider implements RecordWriterProvider { - private static final Logger log = LoggerFactory.getLogger(AvroRecordWriterProvider.class); - private final AvroData avroData = new AvroData(50); - - @Override - public RecordWriter getRecordWriter(String filename, OutputStream out) { - return new RecordWriter() { - final DataFileWriter writer = new DataFileWriter<>(new GenericDatumWriter<>()); - Schema schema; - - @Override - public void write(SinkRecord record) throws IOException { - if (schema == null) { - schema = record.valueSchema(); - try { - log.debug("Opening record writer for: {}", filename); - org.apache.avro.Schema avroSchema = avroData.fromConnectSchema(schema); - writer.setFlushOnEveryBlock(true); - writer.create(avroSchema, out); - } catch (IOException e) { - throw new ConnectException(e); - } - } - Object value = avroData.fromConnectData(schema, record.value()); - // AvroData wraps primitive types so their schema can be included. We need to unwrap - // NonRecordContainers to just their value to properly handle these types - if (value instanceof NonRecordContainer) { - writer.append(((NonRecordContainer) value).getValue()); - } else { - writer.append(value); - } - } - - @Override - public void close() { - try { - writer.close(); - } catch (IOException e) { - throw new DataException(e); - } - } - - @Override - public void commit() { - try { - writer.flush(); - } catch (IOException e) { - throw new DataException(e); - } - } - }; - } -} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/ByteRecordWriterProvider.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/ByteRecordWriterProvider.java deleted file mode 100644 index 9268547b..00000000 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/ByteRecordWriterProvider.java +++ /dev/null @@ -1,58 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.IOException; -import java.io.OutputStream; -import java.nio.charset.StandardCharsets; - -import org.apache.kafka.connect.errors.DataException; -import org.apache.kafka.connect.sink.SinkRecord; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriterProvider; - -public class ByteRecordWriterProvider implements RecordWriterProvider { - private static final Logger log = LoggerFactory.getLogger(ByteRecordWriterProvider.class); - - @Override - public RecordWriter getRecordWriter(String filename, OutputStream out) { - return new RecordWriter() { - - @Override - public void write(SinkRecord record) throws IOException { - byte[] value = null; - byte[] valueBytes = (byte[]) record.value(); - if (filename.contains("avro")) { - value = new byte[valueBytes.length]; - System.arraycopy(valueBytes, 0, value, 0, valueBytes.length); - } else { - byte[] separator = "\n".getBytes(StandardCharsets.UTF_8); - byte[] valueWithSeparator = new byte[valueBytes.length + separator.length]; - System.arraycopy(valueBytes, 0, valueWithSeparator, 0, valueBytes.length); - System.arraycopy(separator, 0, valueWithSeparator, valueBytes.length, separator.length); - value = valueWithSeparator; - } - out.write(value); - } - - @Override - public void close() { - try { - out.close(); - } catch (IOException e) { - throw new DataException(e); - } - } - - @Override - public void commit() { - try { - out.flush(); - } catch (IOException e) { - throw new DataException(e); - } - } - }; - } -} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/JsonRecordWriterProvider.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/JsonRecordWriterProvider.java deleted file mode 100644 index cc46579c..00000000 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/JsonRecordWriterProvider.java +++ /dev/null @@ -1,92 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.IOException; -import java.io.OutputStream; -import java.nio.charset.StandardCharsets; -import java.util.HashMap; -import java.util.Map; - -import org.apache.commons.lang3.ArrayUtils; -import org.apache.kafka.connect.data.Struct; -import org.apache.kafka.connect.errors.ConnectException; -import org.apache.kafka.connect.errors.DataException; -import org.apache.kafka.connect.json.JsonConverter; -import org.apache.kafka.connect.sink.SinkRecord; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import com.fasterxml.jackson.core.JsonGenerator; -import com.fasterxml.jackson.databind.ObjectMapper; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriterProvider; - -public class JsonRecordWriterProvider implements RecordWriterProvider { - private static final Logger log = LoggerFactory.getLogger(JsonRecordWriterProvider.class); - private static final String LINE_SEPARATOR = System.lineSeparator(); - private static final byte[] LINE_SEPARATOR_BYTES = LINE_SEPARATOR.getBytes(StandardCharsets.UTF_8); - - private final ObjectMapper mapper = new ObjectMapper(); - private final JsonConverter converter = new JsonConverter(); - - public JsonRecordWriterProvider() { - Map converterConfig = new HashMap<>(); - converterConfig.put("schemas.enable", "false"); - converterConfig.put("schemas.cache.size", "50"); - this.converter.configure(converterConfig, false); - } - - @Override - public RecordWriter getRecordWriter(final String filename, OutputStream out) { - try { - log.debug("Opening record writer for: {}", filename); - return new RecordWriter() { - final JsonGenerator writer = mapper.getFactory() - .createGenerator(out) - .setRootValueSeparator(null); - - @Override - public void write(SinkRecord record) { - log.trace("Sink record: {}", record); - try { - Object value = record.value(); - if (value instanceof Struct) { - byte[] rawJson = converter.fromConnectData(record.topic(), record.valueSchema(), value); - if (ArrayUtils.isEmpty(rawJson)) { - log.warn("Filtering empty records post-serialization. Record filtered {}", record); // prints everything - } else { - out.write(rawJson); - out.write(LINE_SEPARATOR_BYTES); - } - } else { - writer.writeObject(value); - writer.writeRaw(LINE_SEPARATOR); - } - } catch (IOException e) { - throw new ConnectException(e); - } - } - - @Override - public void commit() { - try { - writer.flush(); - } catch (IOException e) { - throw new DataException(e); - } - } - - @Override - public void close() { - try { - writer.close(); - out.close(); - } catch (IOException e) { - throw new DataException(e); - } - } - }; - } catch (IOException e) { - throw new DataException(e); - } - } -} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/StringRecordWriterProvider.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/StringRecordWriterProvider.java deleted file mode 100644 index 03a789fe..00000000 --- a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/StringRecordWriterProvider.java +++ /dev/null @@ -1,49 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.IOException; -import java.io.OutputStream; -import java.nio.charset.StandardCharsets; - -import org.apache.kafka.connect.errors.DataException; -import org.apache.kafka.connect.sink.SinkRecord; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriterProvider; - -public class StringRecordWriterProvider implements RecordWriterProvider { - private static final Logger log = LoggerFactory.getLogger(StringRecordWriterProvider.class); - - @Override - public RecordWriter getRecordWriter(String filename, OutputStream out) { - return new RecordWriter() { - - @Override - public void write(SinkRecord record) throws IOException { - byte[] value = null; - value = String.format("%s\n", record.value()).getBytes(StandardCharsets.UTF_8); - out.write(value); - } - - @Override - public void close() { - try { - out.close(); - } catch (IOException e) { - throw new DataException(e); - } - } - - @Override - public void commit() { - try { - out.flush(); - } catch (IOException e) { - throw new DataException(e); - } - } - }; - } - -} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/FormatWriterHelper.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/FormatWriterHelper.java new file mode 100644 index 00000000..1cc79775 --- /dev/null +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/FormatWriterHelper.java @@ -0,0 +1,227 @@ +package com.microsoft.azure.kusto.kafka.connect.sink.formatwriter; + +import java.io.IOException; +import java.net.ConnectException; +import java.nio.charset.StandardCharsets; +import java.util.*; + +import org.apache.avro.file.DataFileReader; +import org.apache.avro.file.SeekableByteArrayInput; +import org.apache.avro.generic.GenericData; +import org.apache.avro.generic.GenericDatumReader; +import org.apache.avro.generic.GenericRecord; +import org.apache.avro.io.DatumReader; +import org.apache.kafka.connect.data.Schema; +import org.apache.kafka.connect.data.Struct; +import org.apache.kafka.connect.json.JsonConverter; +import org.jetbrains.annotations.NotNull; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; + +import com.fasterxml.jackson.core.JsonFactory; +import com.fasterxml.jackson.core.JsonParser; +import com.fasterxml.jackson.core.type.TypeReference; +import com.fasterxml.jackson.databind.DeserializationFeature; +import com.fasterxml.jackson.databind.JsonNode; +import com.fasterxml.jackson.databind.ObjectMapper; +import com.microsoft.azure.kusto.ingest.IngestionProperties; + +import io.confluent.kafka.serializers.NonRecordContainer; + +import static com.microsoft.azure.kusto.ingest.IngestionProperties.DataFormat.*; + +public class FormatWriterHelper { + private static final Logger LOGGER = LoggerFactory.getLogger(KustoRecordWriter.class); + private static final ObjectMapper OBJECT_MAPPER = new ObjectMapper().enable(DeserializationFeature.FAIL_ON_TRAILING_TOKENS); + private static final JsonFactory JSON_FACTORY = new JsonFactory(); + private static final TypeReference> MAP_TYPE_REFERENCE = new TypeReference>() {}; + private final JsonConverter KEY_JSON_CONVERTER = new JsonConverter(); + private static final JsonConverter VALUE_JSON_CONVERTER = new JsonConverter(); + private static FormatWriterHelper INSTANCE; + + public static FormatWriterHelper getInstance() { + if (INSTANCE == null) { + INSTANCE = new FormatWriterHelper(); + } + return INSTANCE; + } + + private FormatWriterHelper() { + KEY_JSON_CONVERTER.configure(Collections.singletonMap("schemas.enable", "false"), true); + VALUE_JSON_CONVERTER.configure(Collections.singletonMap("schemas.enable", "false"), false); + } + + public boolean isSchemaFormat(IngestionProperties.DataFormat dataFormat) { + return dataFormat == JSON || dataFormat == MULTIJSON + || dataFormat == AVRO || dataFormat == SINGLEJSON; + + } + + protected boolean isAvro(IngestionProperties.DataFormat dataFormat) { + return IngestionProperties.DataFormat.AVRO.equals(dataFormat) + || IngestionProperties.DataFormat.APACHEAVRO.equals(dataFormat); + } + + public boolean isCsv(IngestionProperties.DataFormat dataFormat) { + return IngestionProperties.DataFormat.CSV.equals(dataFormat); + } + + public @NotNull Map convertAvroRecordToMap(Schema schema, Object value) throws IOException { + Map updatedValue = new HashMap<>(); + if (value != null) { + if (value instanceof NonRecordContainer) { + updatedValue.put(schema.name(), ((NonRecordContainer) value).getValue()); + } else { + if (value instanceof GenericData.Record) { + updatedValue.putAll(avroToJson((GenericData.Record) value)); + } + } + } + return updatedValue; + } + + /** + * @param messageBytes Raw message bytes to transform + * @param defaultKeyOrValueField Default value for Key or Value + * @param dataformat JSON or Avro + * @return a Map of the K-V of JSON + */ + public @NotNull Collection> convertBytesToMap(byte[] messageBytes, + String defaultKeyOrValueField, + IngestionProperties.DataFormat dataformat) throws IOException { + if (messageBytes == null || messageBytes.length == 0) { + return Collections.emptyList(); + } + if (isAvro(dataformat)) { + return bytesToAvroRecord(defaultKeyOrValueField, messageBytes); + } + String bytesAsJson = new String(messageBytes, StandardCharsets.UTF_8); + if (isJson(dataformat)) { + return isValidJson(defaultKeyOrValueField, bytesAsJson) ? parseJson(bytesAsJson) + : Collections.singletonList(Collections.singletonMap(defaultKeyOrValueField, + OBJECT_MAPPER.readTree(messageBytes))); + } else { + return Collections.singletonList(Collections.singletonMap(defaultKeyOrValueField, + Base64.getEncoder().encodeToString(messageBytes))); + } + } + + private static @NotNull Collection> parseJson(String json) throws IOException { + JsonNode jsonData = OBJECT_MAPPER.readTree(json); + if (jsonData.isArray()) { + List> result = new ArrayList<>(); + for (JsonNode node : jsonData) { + result.add(OBJECT_MAPPER.convertValue(node, MAP_TYPE_REFERENCE)); + } + return result; + } else { + return Collections.singletonList(OBJECT_MAPPER.convertValue(jsonData, MAP_TYPE_REFERENCE)); + } + } + + /** + * Convert a given avro record to json and return the encoded bytes. + * @param record The GenericRecord to convert + */ + private Map avroToJson(@NotNull GenericRecord record) throws IOException { + return OBJECT_MAPPER.readerFor(MAP_TYPE_REFERENCE).readValue(record.toString()); + } + + public @NotNull Map structToMap(String topicName, + @NotNull Struct recordData, boolean isKey) throws IOException { + try { + JsonConverter jsonConverter = isKey ? KEY_JSON_CONVERTER : VALUE_JSON_CONVERTER; + byte[] jsonBytes = jsonConverter.fromConnectData(topicName, recordData.schema(), recordData); + return OBJECT_MAPPER.readValue(jsonBytes, MAP_TYPE_REFERENCE); + } catch (IOException e) { + LOGGER.error("Failed to convert Struct to Map", e); + throw e; + } + } + + private boolean isValidJson(String defaultKeyOrValueField, String json) { + try (JsonParser parser = JSON_FACTORY.createParser(json)) { + if (!parser.nextToken().isStructStart()) { + LOGGER.debug("No start token found for json {}. Is key {} ", json, defaultKeyOrValueField); + return false; + } + OBJECT_MAPPER.readTree(json); + } catch (IOException e) { + LOGGER.debug("Parsed data is not json {} , failed with {}", json, e.getMessage()); + return false; + } + return true; + } + + public @NotNull Map convertStringToMap(Object value, + String defaultKeyOrValueField, + IngestionProperties.DataFormat dataFormat) throws IOException { + String objStr = (String) value; + if (isJson(dataFormat) && isValidJson(defaultKeyOrValueField, objStr)) { + return OBJECT_MAPPER.readerFor(MAP_TYPE_REFERENCE).readValue(objStr); + } else { + return Collections.singletonMap(defaultKeyOrValueField, objStr); + } + } + + public void close() { + try { + KEY_JSON_CONVERTER.close(); + VALUE_JSON_CONVERTER.close(); + } catch (Exception e) { + LOGGER.warn("Failed to close JsonConverter", e); + } + } + + private boolean isJson(IngestionProperties.DataFormat dataFormat) { + return IngestionProperties.DataFormat.JSON.equals(dataFormat) + || IngestionProperties.DataFormat.MULTIJSON.equals(dataFormat) + || IngestionProperties.DataFormat.SINGLEJSON.equals(dataFormat); + } + + private Collection> bytesToAvroRecord(String defaultKeyOrValueField, byte[] received_message) { + Map returnValue = new HashMap<>(); + try { + // avro input parser + DatumReader datumReader = new GenericDatumReader<>(); + DataFileReader dataFileReader; + try { + dataFileReader = new DataFileReader<>(new SeekableByteArrayInput(received_message), datumReader); + } catch (Exception e) { + LOGGER.error("Failed to parse AVRO record(1)\n{}", e.getMessage()); + throw new ConnectException( + "Failed to parse AVRO " + "record\n" + e.getMessage()); + } + List> nodes = new ArrayList<>(); + while (dataFileReader.hasNext()) { + String jsonString = dataFileReader.next().toString(); + LOGGER.trace("Encoding AVROBytes yielded {}", jsonString); + try { + Map nodeMap = OBJECT_MAPPER.readValue(jsonString, MAP_TYPE_REFERENCE); + returnValue.putAll(nodeMap); + nodes.add(returnValue); + } catch (IOException e) { + throw new ConnectException( + "Failed to parse JSON" + + " " + + "record\nInput String: " + + jsonString + + "\n" + + e.getMessage()); + } + } + try { + dataFileReader.close(); + } catch (IOException e) { + throw new ConnectException( + "Failed to parse AVRO (2) " + "record\n" + e); + } + return nodes; + } catch (Exception e) { + LOGGER.error("Failed to parse AVRO record (3) \n", e); + return Collections.singletonList( + Collections.singletonMap(defaultKeyOrValueField, + Base64.getEncoder().encodeToString(received_message))); + } + } +} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/HeaderAndMetadataWriter.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/HeaderAndMetadataWriter.java new file mode 100644 index 00000000..f916848d --- /dev/null +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/HeaderAndMetadataWriter.java @@ -0,0 +1,121 @@ +package com.microsoft.azure.kusto.kafka.connect.sink.formatwriter; + +import java.io.IOException; +import java.net.ConnectException; +import java.nio.charset.StandardCharsets; +import java.util.Collection; +import java.util.Collections; +import java.util.HashMap; +import java.util.Map; + +import org.apache.avro.generic.GenericData; +import org.apache.kafka.connect.data.Schema; +import org.apache.kafka.connect.data.Struct; +import org.apache.kafka.connect.sink.SinkRecord; +import org.jetbrains.annotations.NotNull; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; + +import com.fasterxml.jackson.databind.ObjectMapper; +import com.fasterxml.jackson.databind.SerializationFeature; +import com.microsoft.azure.kusto.ingest.IngestionProperties; + +import io.confluent.kafka.serializers.NonRecordContainer; + +public abstract class HeaderAndMetadataWriter { + public static final ObjectMapper OBJECT_MAPPER = new ObjectMapper().disable(SerializationFeature.FAIL_ON_EMPTY_BEANS); + public static final String LINE_SEPARATOR = System.lineSeparator(); + protected static final Logger LOGGER = LoggerFactory.getLogger(HeaderAndMetadataWriter.class); + public String HEADERS_FIELD = "headers"; + public String KEYS_FIELD = "keys"; + public String KEY_FIELD = "key"; + public String VALUE_FIELD = "value"; + + public String KAFKA_METADATA_FIELD = "kafkamd"; + public String TOPIC = "topic"; + public String PARTITION = "partition"; + public String OFFSET = "offset"; + + protected final FormatWriterHelper formatWriterHelper = FormatWriterHelper.getInstance(); + + @NotNull + public Map getHeadersAsMap(@NotNull SinkRecord record) { + Map headers = new HashMap<>(); + record.headers().forEach(header -> headers.put(header.key(), header.value())); + return headers; + } + + /** + * Convert SinkRecord to CSV + * + * @param record SinkRecord + * @param isKey boolean + * @return String + */ + public String convertSinkRecordToCsv(@NotNull SinkRecord record, boolean isKey) { + if (isKey) { + if (record.key() instanceof byte[]) { + return record.key() == null ? "" : new String((byte[]) record.key(), StandardCharsets.UTF_8); + } else { + return record.key() == null ? "" : record.key().toString(); + } + } else { + if (record.value() instanceof byte[]) { + return record.value() == null ? "" : new String((byte[]) record.value(), StandardCharsets.UTF_8); + } else { + return record.value() == null ? "" : record.value().toString(); + } + } + } + + @NotNull + @SuppressWarnings(value = "unchecked") + public Collection> convertSinkRecordToMap(@NotNull SinkRecord record, boolean isKey, + IngestionProperties.DataFormat dataFormat) throws IOException { + Object recordValue = isKey ? record.key() : record.value(); + Schema schema = isKey ? record.keySchema() : record.valueSchema(); + String defaultKeyOrValueField = isKey ? KEY_FIELD : VALUE_FIELD; + if (recordValue == null) { + return Collections.emptyList(); + } + if (recordValue instanceof Struct) { + Struct recordStruct = (Struct) recordValue; + return Collections.singletonList(formatWriterHelper.structToMap(record.topic(), recordStruct, isKey)); + } + // Is Avro Data + if (recordValue instanceof GenericData.Record || recordValue instanceof NonRecordContainer) { + return Collections.singletonList(formatWriterHelper.convertAvroRecordToMap(schema, recordValue)); + } + // String or JSON + if (recordValue instanceof String) { + return Collections.singletonList(formatWriterHelper.convertStringToMap(recordValue, + defaultKeyOrValueField, dataFormat)); + } + // Map + if (recordValue instanceof Map) { + return Collections.singletonList((Map) recordValue); + } + // is a byte array + if (FormatWriterHelper.getInstance().isSchemaFormat(dataFormat)) { + if (recordValue instanceof byte[]) { + return formatWriterHelper.convertBytesToMap((byte[]) recordValue, defaultKeyOrValueField, dataFormat); + } else { + String fieldName = isKey ? KEY_FIELD : VALUE_FIELD; + return Collections.singletonList(Collections.singletonMap(fieldName, recordValue)); + } + } else { + String errorMessage = String.format("DataFormat %s is not supported in the connector though " + + "it may be supported for ingestion in ADX. Please raise a feature request if a " + + "new format has to be supported.", dataFormat); + throw new ConnectException(errorMessage); + } + } + + public Map getKafkaMetaDataAsMap(@NotNull SinkRecord record) { + Map kafkaMetadata = new HashMap<>(); + kafkaMetadata.put(TOPIC, record.topic()); + kafkaMetadata.put(PARTITION, String.valueOf(record.kafkaPartition())); + kafkaMetadata.put(OFFSET, String.valueOf(record.kafkaOffset())); + return kafkaMetadata; + } +} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriter.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriter.java new file mode 100644 index 00000000..8c7903b1 --- /dev/null +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriter.java @@ -0,0 +1,120 @@ +package com.microsoft.azure.kusto.kafka.connect.sink.formatwriter; + +import java.io.IOException; +import java.io.OutputStream; +import java.nio.charset.StandardCharsets; +import java.util.Collection; +import java.util.HashMap; +import java.util.Map; + +import org.apache.commons.text.StringEscapeUtils; +import org.apache.kafka.connect.data.Schema; +import org.apache.kafka.connect.errors.ConnectException; +import org.apache.kafka.connect.errors.DataException; +import org.apache.kafka.connect.sink.SinkRecord; + +import com.fasterxml.jackson.core.JsonGenerator; +import com.microsoft.azure.kusto.ingest.IngestionProperties; +import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; + +public class KustoRecordWriter extends HeaderAndMetadataWriter implements RecordWriter { + private final String filename; + private final JsonGenerator writer; + private final OutputStream plainOutputStream; + private Schema schema; + + public KustoRecordWriter(String filename, OutputStream out) { + this.filename = filename; + this.plainOutputStream = out; + try { + this.writer = OBJECT_MAPPER.getFactory() + .createGenerator(out) + .setRootValueSeparator(null); + } catch (IOException e) { + throw new ConnectException(e); + } + } + + /** + * @param record the record to persist. + * @param dataFormat the data format to use. + * @throws IOException if an error occurs while writing the record. + */ + @Override + public void write(SinkRecord record, IngestionProperties.DataFormat dataFormat) throws IOException { + if (schema == null) { + schema = record.valueSchema(); + LOGGER.debug("Opening record writer for: {}", filename); + } + Map parsedHeaders = getHeadersAsMap(record); + Map kafkaMd = getKafkaMetaDataAsMap(record); + if (FormatWriterHelper.getInstance().isCsv(dataFormat)) { + String serializedKeys = StringEscapeUtils.escapeCsv(convertSinkRecordToCsv(record, true)); + String serializedValues = convertSinkRecordToCsv(record, false); + String serializedHeaders = StringEscapeUtils.escapeCsv(OBJECT_MAPPER.writeValueAsString(parsedHeaders)); + String serializedMetadata = StringEscapeUtils.escapeCsv(OBJECT_MAPPER.writeValueAsString(kafkaMd)); + String formattedRecord = String.format("%s,%s,%s,%s", serializedValues, serializedKeys, + serializedHeaders, serializedMetadata); + LOGGER.trace("Writing record to file: Keys {} , Values {} , Headers {} , OverallRecord {}", + serializedKeys, serializedValues, serializedHeaders, formattedRecord); + this.plainOutputStream.write( + formattedRecord.getBytes(StandardCharsets.UTF_8)); + this.plainOutputStream.write(LINE_SEPARATOR.getBytes(StandardCharsets.UTF_8)); + } else { + Map parsedKeys = convertSinkRecordToMap(record, true, dataFormat).stream().reduce(new HashMap<>(), + (acc, map) -> { + acc.putAll(map); + return acc; + }); + Collection> parsedValues = convertSinkRecordToMap(record, false, dataFormat); + + parsedValues.forEach(parsedValue -> { + Map updatedValue = (record.value() == null) ? new HashMap<>() : new HashMap<>(parsedValue); + /* Add all the key fields */ + if (record.key() != null) { + if (parsedKeys.size() == 1 && parsedKeys.containsKey(KEY_FIELD)) { + updatedValue.put(KEYS_FIELD, parsedKeys.get(KEY_FIELD)); + } else { + updatedValue.put(KEYS_FIELD, parsedKeys); + } + } + /* End add key fields */ + /* Add record headers */ + if (record.headers() != null && !record.headers().isEmpty()) { + updatedValue.put(HEADERS_FIELD, parsedHeaders); + } + /* End record headers */ + /* Add metadata fields */ + updatedValue.put(KAFKA_METADATA_FIELD, kafkaMd); + /* End metadata fields */ + try { + /* Write out each value row with key and header fields */ + writer.writeObject(updatedValue); + writer.writeRaw(LINE_SEPARATOR); + } catch (IOException e) { + LOGGER.error("Error writing record to file: {}", filename, e); + throw new ConnectException(e); + } + }); + } + } + + @Override + public void close() { + try { + writer.close(); + formatWriterHelper.close(); + } catch (IOException e) { + throw new DataException(e); + } + } + + @Override + public void commit() { + try { + writer.flush(); + } catch (IOException e) { + throw new DataException(e); + } + } +} diff --git a/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterProvider.java b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterProvider.java new file mode 100644 index 00000000..b83035e8 --- /dev/null +++ b/src/main/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterProvider.java @@ -0,0 +1,13 @@ +package com.microsoft.azure.kusto.kafka.connect.sink.formatwriter; + +import java.io.OutputStream; + +import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; +import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriterProvider; + +public class KustoRecordWriterProvider implements RecordWriterProvider { + @Override + public RecordWriter getRecordWriter(String filename, OutputStream out) { + return new KustoRecordWriter(filename, out); + } +} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriterTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriterTest.java index 8b7cabce..45adc4b2 100644 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriterTest.java +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/FileWriterTest.java @@ -1,255 +1,266 @@ -package com.microsoft.azure.kusto.kafka.connect.sink; - -import java.io.ByteArrayInputStream; -import java.io.ByteArrayOutputStream; -import java.io.File; -import java.io.FileInputStream; -import java.io.IOException; -import java.nio.file.Paths; -import java.util.AbstractMap; -import java.util.ArrayList; -import java.util.Arrays; -import java.util.HashMap; -import java.util.List; -import java.util.Map; -import java.util.concurrent.locks.ReentrantReadWriteLock; -import java.util.function.Consumer; -import java.util.function.Function; -import java.util.zip.GZIPInputStream; - -import org.apache.commons.io.FileUtils; -import org.apache.commons.io.IOUtils; -import org.apache.kafka.connect.data.Schema; -import org.apache.kafka.connect.sink.SinkRecord; -import org.junit.jupiter.api.AfterEach; -import org.junit.jupiter.api.Assertions; -import org.junit.jupiter.api.BeforeEach; -import org.junit.jupiter.api.Test; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import com.microsoft.azure.kusto.ingest.IngestionProperties; -import com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConfig.BehaviorOnError; - -import static com.microsoft.azure.kusto.kafka.connect.sink.Utils.createDirectoryWithPermissions; -import static com.microsoft.azure.kusto.kafka.connect.sink.Utils.getFilesCount; - -public class FileWriterTest { - private static final Logger log = LoggerFactory.getLogger(FileWriterTest.class); - - IngestionProperties ingestionProps; - private File currentDirectory; - - static Function getAssertFileConsumerFunction(String msg) { - return (SourceFile f) -> { - try (FileInputStream fileInputStream = new FileInputStream(f.file)) { - byte[] bytes = IOUtils.toByteArray(fileInputStream); - try (ByteArrayInputStream bin = new ByteArrayInputStream(bytes); - GZIPInputStream gzipper = new GZIPInputStream(bin)) { - - byte[] buffer = new byte[1024]; - ByteArrayOutputStream out = new ByteArrayOutputStream(); - - int len; - while ((len = gzipper.read(buffer)) > 0) { - out.write(buffer, 0, len); - } - - gzipper.close(); - out.close(); - String s = out.toString(); - - Assertions.assertEquals(s, msg); - } - } catch (IOException e) { - log.error("Error running test", e); - Assertions.fail(e.getMessage()); - } - return null; - }; - } - - @BeforeEach - public final void before() { - currentDirectory = Utils.getCurrentWorkingDirectory(); - ingestionProps = new IngestionProperties("db", "table"); - ingestionProps.setDataFormat(IngestionProperties.DataFormat.CSV); - } - - @AfterEach - public final void afterEach() { - FileUtils.deleteQuietly(currentDirectory); - } - - @Test - public void testOpen() throws IOException { - String path = Paths.get(currentDirectory.getPath(), "testWriterOpen").toString(); - Assertions.assertTrue(createDirectoryWithPermissions(path)); - Assertions.assertEquals(0, getFilesCount(path)); - final String FILE_PATH = Paths.get(path, "ABC").toString(); - final int MAX_FILE_SIZE = 128; - Consumer trackFiles = (SourceFile f) -> { - }; - Function generateFileName = (Long l) -> FILE_PATH; - try (FileWriter fileWriter = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 30000, new ReentrantReadWriteLock(), - ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true)) { - String msg = "Line number 1: This is a message from the other size"; - SinkRecord record = new SinkRecord("topic", 1, null, null, Schema.BYTES_SCHEMA, msg.getBytes(), 10); - fileWriter.initializeRecordWriter(record); - fileWriter.openFile(null); - Assertions.assertEquals(1, getFilesCount(path)); - Assertions.assertEquals(0, fileWriter.currentFile.rawBytes); - Assertions.assertEquals(FILE_PATH, fileWriter.currentFile.path); - Assertions.assertTrue(fileWriter.currentFile.file.canWrite()); - fileWriter.rollback(); - } - } - - @Test - public void testGzipFileWriter() throws IOException { - String path = Paths.get(currentDirectory.getPath(), "testGzipFileWriter").toString(); - Assertions.assertTrue(createDirectoryWithPermissions(path)); - Assertions.assertEquals(0, getFilesCount(path)); - HashMap files = new HashMap<>(); - final int MAX_FILE_SIZE = 100; - Consumer trackFiles = (SourceFile f) -> files.put(f.path, f.rawBytes); - Function generateFileName = (Long l) -> Paths.get(path, String.valueOf(java.util.UUID.randomUUID())) + "csv.gz"; - try (FileWriter fileWriter = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 30000, new ReentrantReadWriteLock(), - ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true)) { - for (int i = 0; i < 9; i++) { - String msg = String.format("Line number %d : This is a message from the other size", i); - SinkRecord record1 = new SinkRecord("topic", 1, null, null, Schema.BYTES_SCHEMA, msg.getBytes(), 10); - fileWriter.writeData(record1); - } - Assertions.assertEquals(4, files.size()); - // should still have 1 open file at this point... - Assertions.assertEquals(1, getFilesCount(path)); - // close current file - fileWriter.rotate(54L); - Assertions.assertEquals(5, files.size()); - List sortedFiles = new ArrayList<>(files.values()); - sortedFiles.sort((Long x, Long y) -> (int) (y - x)); - Assertions.assertEquals(sortedFiles, - Arrays.asList((long) 108, (long) 108, (long) 108, (long) 108, (long) 54)); - // make sure folder is clear once done - with only the new file - Assertions.assertEquals(1, getFilesCount(path)); - } - } - - @Test - public void testGzipFileWriterFlush() throws IOException, InterruptedException { - String path = Paths.get(currentDirectory.getPath(), "testGzipFileWriter2").toString(); - Assertions.assertTrue(createDirectoryWithPermissions(path)); - HashMap files = new HashMap<>(); - final int MAX_FILE_SIZE = 128 * 2; - Consumer trackFiles = (SourceFile f) -> files.put(f.path, f.rawBytes); - Function generateFileName = (Long l) -> Paths.get(path, java.util.UUID.randomUUID().toString()) + "csv.gz"; - // Expect no files to be ingested as size is small and flushInterval is big - FileWriter fileWriter = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 30000, new ReentrantReadWriteLock(), - ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true); - String msg = "Message"; - SinkRecord record = new SinkRecord("topic", 1, null, null, null, msg, 10); - fileWriter.writeData(record); - Thread.sleep(1000); - Assertions.assertEquals(0, files.size()); - fileWriter.rotate(10L); - fileWriter.stop(); - Assertions.assertEquals(1, files.size()); - - String path2 = Paths.get(currentDirectory.getPath(), "testGzipFileWriter2_2").toString(); - Assertions.assertTrue(createDirectoryWithPermissions(path2)); - Function generateFileName2 = (Long l) -> Paths.get(path2, java.util.UUID.randomUUID().toString()).toString(); - // Expect one file to be ingested as flushInterval had changed and is shorter than sleep time - FileWriter fileWriter2 = new FileWriter(path2, MAX_FILE_SIZE, trackFiles, generateFileName2, 1000, new ReentrantReadWriteLock(), - ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true); - String msg2 = "Second Message"; - SinkRecord record1 = new SinkRecord("topic", 1, null, null, null, msg2, 10); - fileWriter2.writeData(record1); - Thread.sleep(1050); - Assertions.assertEquals(2, files.size()); - List sortedFiles = new ArrayList<>(files.values()); - sortedFiles.sort((Long x, Long y) -> (int) (y - x)); - Assertions.assertEquals(sortedFiles, Arrays.asList((long) 15, (long) 8)); - // make sure folder is clear once done - fileWriter2.close(); - Assertions.assertEquals(1, getFilesCount(path)); - } - - @Test - public void offsetCheckByInterval() throws InterruptedException, IOException { - // This test will check that lastCommitOffset is set to the right value, when ingests are done by flush interval. - // There will be a write operation followed by a flush which will track files and sleep. - // While it sleeps there will be another write attempt which should wait on the lock and another flush later. - // Resulting in first record to be with offset 1 and second with offset 2. - - ArrayList> files = new ArrayList<>(); - final int MAX_FILE_SIZE = 128 * 2; - ReentrantReadWriteLock reentrantReadWriteLock = new ReentrantReadWriteLock(); - final ArrayList committedOffsets = new ArrayList<>(); - class Offsets { - private long currentOffset = 0; - } - final Offsets offsets = new Offsets(); - Consumer trackFiles = (SourceFile f) -> { - committedOffsets.add(offsets.currentOffset); - files.add(new AbstractMap.SimpleEntry<>(f.path, f.rawBytes)); - // return null; - }; - String path = Paths.get(currentDirectory.getPath(), "offsetCheckByInterval").toString(); - Assertions.assertTrue(createDirectoryWithPermissions(path)); - Function generateFileName = (Long offset) -> { - if (offset == null) { - offset = offsets.currentOffset; - } - return Paths.get(path, Long.toString(offset)).toString(); - }; - try (FileWriter fileWriter2 = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 500, reentrantReadWriteLock, - ingestionProps.getDataFormat(), - BehaviorOnError.FAIL, true)) { - String msg2 = "Second Message"; - reentrantReadWriteLock.readLock().lock(); - long recordOffset = 1; - SinkRecord record = new SinkRecord("topic", 1, null, null, Schema.BYTES_SCHEMA, msg2.getBytes(), recordOffset); - fileWriter2.writeData(record); - offsets.currentOffset = recordOffset; - // Wake the flush by interval in the middle of the writing - Thread.sleep(510); - recordOffset = 2; - SinkRecord record2 = new SinkRecord("TestTopic", 1, null, null, Schema.BYTES_SCHEMA, msg2.getBytes(), recordOffset); - - fileWriter2.writeData(record2); - offsets.currentOffset = recordOffset; - reentrantReadWriteLock.readLock().unlock(); - - // Context switch - Thread.sleep(10); - reentrantReadWriteLock.readLock().lock(); - recordOffset = 3; - SinkRecord record3 = new SinkRecord("TestTopic", 1, null, null, Schema.BYTES_SCHEMA, msg2.getBytes(), recordOffset); - - offsets.currentOffset = recordOffset; - fileWriter2.writeData(record3); - reentrantReadWriteLock.readLock().unlock(); - Thread.sleep(550); - // Assertions - Assertions.assertEquals(2, files.size()); - - // Make sure that the first file is from offset 1 till 2 and second is from 3 till 3 - Assertions.assertEquals(30L, files.stream().map(Map.Entry::getValue).toArray(Long[]::new)[0]); - Assertions.assertEquals(15L, files.stream().map(Map.Entry::getValue).toArray(Long[]::new)[1]); - Assertions.assertEquals("1", - files.stream().map((s) -> s.getKey().substring(path.length() + 1)).toArray(String[]::new)[0]); - Assertions.assertEquals("3", - files.stream().map((s) -> s.getKey().substring(path.length() + 1)).toArray(String[]::new)[1]); - Assertions.assertEquals(committedOffsets, new ArrayList() { - { - add(2L); - add(3L); - } - }); - // make sure folder is clear once done - fileWriter2.stop(); - Assertions.assertEquals(0, getFilesCount(path)); - } - } -} +package com.microsoft.azure.kusto.kafka.connect.sink; + +import java.io.ByteArrayInputStream; +import java.io.ByteArrayOutputStream; +import java.io.File; +import java.io.FileInputStream; +import java.io.IOException; +import java.nio.file.Paths; +import java.util.AbstractMap; +import java.util.ArrayList; +import java.util.Arrays; +import java.util.HashMap; +import java.util.List; +import java.util.Map; +import java.util.concurrent.locks.ReentrantReadWriteLock; +import java.util.function.Consumer; +import java.util.function.Function; +import java.util.zip.GZIPInputStream; + +import org.apache.commons.io.FileUtils; +import org.apache.commons.io.IOUtils; +import org.apache.kafka.connect.data.Schema; +import org.apache.kafka.connect.sink.SinkRecord; +import org.jetbrains.annotations.Contract; +import org.jetbrains.annotations.NotNull; +import org.junit.jupiter.api.AfterEach; +import org.junit.jupiter.api.Assertions; +import org.junit.jupiter.api.BeforeEach; +import org.junit.jupiter.api.Test; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; + +import com.microsoft.azure.kusto.ingest.IngestionProperties; +import com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConfig.BehaviorOnError; + +import static com.microsoft.azure.kusto.kafka.connect.sink.Utils.createDirectoryWithPermissions; +import static com.microsoft.azure.kusto.kafka.connect.sink.Utils.getFilesCount; + +public class FileWriterTest { + private static final Logger log = LoggerFactory.getLogger(FileWriterTest.class); + + IngestionProperties ingestionProps; + private File currentDirectory; + + @Contract(pure = true) + static @NotNull Function getAssertFileConsumerFunction(String msg) { + return (SourceFile f) -> { + try (FileInputStream fileInputStream = new FileInputStream(f.file)) { + byte[] bytes = IOUtils.toByteArray(fileInputStream); + try (ByteArrayInputStream bin = new ByteArrayInputStream(bytes); + GZIPInputStream gzipper = new GZIPInputStream(bin)) { + + byte[] buffer = new byte[1024]; + ByteArrayOutputStream out = new ByteArrayOutputStream(); + + int len; + while ((len = gzipper.read(buffer)) > 0) { + out.write(buffer, 0, len); + } + + gzipper.close(); + out.close(); + String s = out.toString(); + + Assertions.assertEquals(s, msg); + } + } catch (IOException e) { + log.error("Error running test", e); + Assertions.fail(e.getMessage()); + } + return null; + }; + } + + @BeforeEach + public final void before() { + currentDirectory = Utils.getCurrentWorkingDirectory(); + ingestionProps = new IngestionProperties("db", "table"); + ingestionProps.setDataFormat(IngestionProperties.DataFormat.CSV); + } + + @AfterEach + public final void afterEach() { + FileUtils.deleteQuietly(currentDirectory); + } + + @Test + public void testOpen() throws IOException { + String path = Paths.get(currentDirectory.getPath(), "testWriterOpen").toString(); + Assertions.assertTrue(createDirectoryWithPermissions(path)); + Assertions.assertEquals(0, getFilesCount(path)); + final String FILE_PATH = Paths.get(path, "ABC").toString(); + final int MAX_FILE_SIZE = 128; + Consumer trackFiles = (SourceFile f) -> { + }; + Function generateFileName = (Long l) -> FILE_PATH; + try (FileWriter fileWriter = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 30000, new ReentrantReadWriteLock(), + ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true)) { + String msg = "Line number 1: This is a message from the other size"; + SinkRecord record = new SinkRecord("topic", 1, null, null, Schema.BYTES_SCHEMA, msg.getBytes(), 10); + fileWriter.initializeRecordWriter(record); + fileWriter.openFile(null); + Assertions.assertEquals(1, getFilesCount(path)); + Assertions.assertEquals(0, fileWriter.currentFile.rawBytes); + Assertions.assertEquals(FILE_PATH, fileWriter.currentFile.path); + Assertions.assertTrue(fileWriter.currentFile.file.canWrite()); + fileWriter.rollback(); + } + } + + @Test + public void testGzipFileWriter() throws IOException { + String path = Paths.get(currentDirectory.getPath(), "testGzipFileWriter").toString(); + Assertions.assertTrue(createDirectoryWithPermissions(path)); + Assertions.assertEquals(0, getFilesCount(path)); + HashMap files = new HashMap<>(); + final int MAX_FILE_SIZE = 225; // sizeof(,'','','{"partition":"1","offset":"1","topic":"topic"}'\n) * 2 , Similar multiple applied for the first test + Consumer trackFiles = (SourceFile f) -> files.put(f.path, f.rawBytes); + Function generateFileName = (Long l) -> Paths.get(path, String.valueOf(java.util.UUID.randomUUID())) + "csv.gz"; + try (FileWriter fileWriter = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 30000, new ReentrantReadWriteLock(), + ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true)) { + for (int i = 0; i < 9; i++) { + String msg = String.format("Line number %d : This is a message from the other size", i); + SinkRecord record1 = new SinkRecord("topic", 1, null, null, Schema.BYTES_SCHEMA, msg.getBytes(), 10); + fileWriter.writeData(record1); + } + Assertions.assertEquals(4, files.size()); + // should still have 1 open file at this point... + Assertions.assertEquals(1, getFilesCount(path)); + // close current file + fileWriter.rotate(54L); + Assertions.assertEquals(5, files.size()); + List sortedFiles = new ArrayList<>(files.values()); + sortedFiles.sort((Long x, Long y) -> (int) (y - x)); + Assertions.assertEquals( + Arrays.asList((long) 240, (long) 240, (long) 240, (long) 240, (long) 120), + sortedFiles); + // make sure folder is clear once done - with only the new file + Assertions.assertEquals(1, getFilesCount(path)); + } + } + + @Test + public void testGzipFileWriterFlush() throws IOException, InterruptedException { + String path = Paths.get(currentDirectory.getPath(), "testGzipFileWriter2").toString(); + Assertions.assertTrue(createDirectoryWithPermissions(path)); + HashMap files = new HashMap<>(); + final int MAX_FILE_SIZE = 128 * 2; + Consumer trackFiles = (SourceFile f) -> files.put(f.path, f.rawBytes); + Function generateFileName = (Long l) -> Paths.get(path, java.util.UUID.randomUUID().toString()) + "csv.gz"; + // Expect no files to be ingested as size is small and flushInterval is big + FileWriter fileWriter = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 30000, new ReentrantReadWriteLock(), + ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true); + String msg = "Message"; + SinkRecord record = new SinkRecord("topic", 1, null, null, null, msg, 10); + fileWriter.writeData(record); + Thread.sleep(1000); + Assertions.assertEquals(0, files.size()); + fileWriter.rotate(10L); + fileWriter.stop(); + Assertions.assertEquals(1, files.size()); + + String path2 = Paths.get(currentDirectory.getPath(), "testGzipFileWriter2_2").toString(); + Assertions.assertTrue(createDirectoryWithPermissions(path2)); + Function generateFileName2 = (Long l) -> Paths.get(path2, java.util.UUID.randomUUID().toString()).toString(); + // Expect one file to be ingested as flushInterval had changed and is shorter than sleep time + FileWriter fileWriter2 = new FileWriter(path2, MAX_FILE_SIZE, trackFiles, generateFileName2, 1000, new ReentrantReadWriteLock(), + ingestionProps.getDataFormat(), BehaviorOnError.FAIL, true); + String msg2 = "Second Message"; + SinkRecord record1 = new SinkRecord("topic", 1, null, null, null, msg2, 10); + fileWriter2.writeData(record1); + Thread.sleep(1050); + Assertions.assertEquals(2, files.size()); + List sortedFiles = new ArrayList<>(files.values()); + sortedFiles.sort((Long x, Long y) -> (int) (y - x)); + Assertions.assertEquals(sortedFiles, Arrays.asList((long) 81, (long) 74)); + // make sure folder is clear once done + fileWriter2.close(); + Assertions.assertEquals(1, getFilesCount(path)); + } + + @Test + public void offsetCheckByInterval() throws InterruptedException, IOException { + // This test will check that lastCommitOffset is set to the right value, when ingests are done by flush interval. + // There will be a write operation followed by a flush which will track files and sleep. + // While it sleeps there will be another write attempt which should wait on the lock and another flush later. + // Resulting in first record to be with offset 1 and second with offset 2. + + ArrayList> files = new ArrayList<>(); + final int MAX_FILE_SIZE = 128 * 2; + ReentrantReadWriteLock reentrantReadWriteLock = new ReentrantReadWriteLock(); + final ArrayList committedOffsets = new ArrayList<>(); + class Offsets { + private long currentOffset = 0; + } + final Offsets offsets = new Offsets(); + Consumer trackFiles = (SourceFile f) -> { + committedOffsets.add(offsets.currentOffset); + files.add(new AbstractMap.SimpleEntry<>(f.path, f.rawBytes)); + // return null; + }; + String path = Paths.get(currentDirectory.getPath(), "offsetCheckByInterval").toString(); + Assertions.assertTrue(createDirectoryWithPermissions(path)); + Function generateFileName = (Long offset) -> { + if (offset == null) { + offset = offsets.currentOffset; + } + return Paths.get(path, Long.toString(offset)).toString(); + }; + try (FileWriter fileWriter2 = new FileWriter(path, MAX_FILE_SIZE, trackFiles, generateFileName, 500, + reentrantReadWriteLock, + ingestionProps.getDataFormat(), + BehaviorOnError.FAIL, true)) { + String msg2 = "Second Message"; + reentrantReadWriteLock.readLock().lock(); + long recordOffset = 1; + SinkRecord record = new SinkRecord("topic", 1, null, null, Schema.BYTES_SCHEMA, msg2.getBytes(), recordOffset); + fileWriter2.writeData(record); + offsets.currentOffset = recordOffset; + // Wake the flush by interval in the middle of the writing + Thread.sleep(510); + recordOffset = 2; + SinkRecord record2 = new SinkRecord("TestTopic", 1, null, null, Schema.BYTES_SCHEMA, msg2.getBytes(), recordOffset); + + fileWriter2.writeData(record2); + offsets.currentOffset = recordOffset; + reentrantReadWriteLock.readLock().unlock(); + + // Context switch + Thread.sleep(10); + reentrantReadWriteLock.readLock().lock(); + recordOffset = 3; + SinkRecord record3 = new SinkRecord("TestTopic", 1, null, null, Schema.BYTES_SCHEMA, msg2.getBytes(), recordOffset); + + offsets.currentOffset = recordOffset; + fileWriter2.writeData(record3); + reentrantReadWriteLock.readLock().unlock(); + Thread.sleep(550); + // Assertions + Assertions.assertEquals(2, files.size()); + + // Make sure that the first file is from offset 1 till 2 and second is from 3 till 3 + /* + * > Why is this 30 before ? 2 * "Second Message" + NewLines for both 6(Second)+1(Space)+7(Message)+1(New Line) -> 15 2 of these => 30 + * + * > Why did this become 146 ? The CSV now becomes : 'Second Message','','','{"partition":"1","offset":"1","topic":"topic"}'\n 2 of these become 146 + * bytes + */ + Assertions.assertEquals(164L, files.stream().map(Map.Entry::getValue).toArray(Long[]::new)[0]); + Assertions.assertEquals(84L, files.stream().map(Map.Entry::getValue).toArray(Long[]::new)[1]); + Assertions.assertEquals("1", + files.stream().map((s) -> s.getKey().substring(path.length() + 1)).toArray(String[]::new)[0]); + Assertions.assertEquals("3", + files.stream().map((s) -> s.getKey().substring(path.length() + 1)).toArray(String[]::new)[1]); + Assertions.assertEquals(committedOffsets, new ArrayList() { + { + add(2L); + add(3L); + } + }); + // make sure folder is clear once done + fileWriter2.stop(); + Assertions.assertEquals(0, getFilesCount(path)); + } + } +} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConnectorConfigTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConnectorConfigTest.java index 8f1ff0bb..ababf082 100644 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConnectorConfigTest.java +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkConnectorConfigTest.java @@ -10,7 +10,6 @@ import com.fasterxml.jackson.core.JsonProcessingException; import com.microsoft.azure.kusto.data.auth.ConnectionStringBuilder; -import com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConfig.BehaviorOnError; import static com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConfig.KUSTO_SINK_ENABLE_TABLE_VALIDATION; import static org.junit.jupiter.api.Assertions.fail; @@ -34,7 +33,7 @@ public void shouldHaveDefaultValues() { Assertions.assertTrue(config.getFlushSizeBytes() > 0); Assertions.assertTrue(config.getFlushInterval() > 0); Assertions.assertFalse(config.isDlqEnabled()); - Assertions.assertEquals(BehaviorOnError.FAIL, config.getBehaviorOnError()); + Assertions.assertEquals(KustoSinkConfig.BehaviorOnError.FAIL, config.getBehaviorOnError()); } @Test diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTaskTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTaskTest.java index 109af4a9..5f69ce47 100644 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTaskTest.java +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/KustoSinkTaskTest.java @@ -122,7 +122,7 @@ public void getTable() { assertEquals("Mapping", kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getIngestionMapping().getIngestionMappingReference()); assertEquals("db2", kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getDatabaseName()); assertEquals("table2", kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getTableName()); - assertEquals(IngestionProperties.DataFormat.MULTIJSON, kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getDataFormat()); + assertEquals(IngestionProperties.DataFormat.JSON, kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getDataFormat()); Assertions.assertNull(kustoSinkTaskSpy.getIngestionProps("topic3")); } } @@ -141,7 +141,7 @@ public void getTableWithoutMapping() { assertEquals(IngestionProperties.DataFormat.CSV, kustoSinkTaskSpy.getIngestionProps("topic1").ingestionProperties.getDataFormat()); assertEquals("db2", kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getDatabaseName()); assertEquals("table2", kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getTableName()); - assertEquals(IngestionProperties.DataFormat.MULTIJSON, kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getDataFormat()); + assertEquals(IngestionProperties.DataFormat.JSON, kustoSinkTaskSpy.getIngestionProps("topic2").ingestionProperties.getDataFormat()); Assertions.assertNull(kustoSinkTaskSpy.getIngestionProps("topic3")); } } diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriterTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriterTest.java index 33c2193b..4d6d7ffd 100644 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriterTest.java +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/TopicPartitionWriterTest.java @@ -1,379 +1,368 @@ -package com.microsoft.azure.kusto.kafka.connect.sink; - -import java.io.ByteArrayOutputStream; -import java.io.File; -import java.io.IOException; -import java.nio.charset.StandardCharsets; -import java.nio.file.Paths; -import java.util.ArrayList; -import java.util.Collections; -import java.util.HashMap; -import java.util.List; -import java.util.Map; -import java.util.Objects; -import java.util.Properties; -import java.util.function.Function; - -import org.apache.commons.io.FileUtils; -import org.apache.commons.io.IOUtils; -import org.apache.kafka.clients.producer.KafkaProducer; -import org.apache.kafka.clients.producer.MockProducer; -import org.apache.kafka.clients.producer.Producer; -import org.apache.kafka.clients.producer.ProducerRecord; -import org.apache.kafka.common.KafkaException; -import org.apache.kafka.common.TopicPartition; -import org.apache.kafka.common.serialization.ByteArraySerializer; -import org.apache.kafka.connect.data.Schema; -import org.apache.kafka.connect.sink.SinkRecord; -import org.junit.jupiter.api.AfterEach; -import org.junit.jupiter.api.Assertions; -import org.junit.jupiter.api.BeforeAll; -import org.junit.jupiter.api.BeforeEach; -import org.junit.jupiter.api.Test; -import org.mockito.ArgumentCaptor; -import org.slf4j.Logger; -import org.slf4j.LoggerFactory; - -import com.microsoft.azure.kusto.ingest.IngestClient; -import com.microsoft.azure.kusto.ingest.IngestionProperties; -import com.microsoft.azure.kusto.ingest.source.FileSourceInfo; - -import static org.junit.jupiter.api.Assertions.assertThrows; -import static org.junit.jupiter.api.Assertions.fail; -import static org.mockito.Mockito.*; - -//TODO parts of this test needs to be re-formatted and may need rewriting -public class TopicPartitionWriterTest { - private static final Logger log = LoggerFactory.getLogger(TopicPartitionWriterTest.class); - - private static final String KUSTO_INGEST_CLUSTER_URL = "https://ingest-cluster.kusto.windows.net"; - private static final String KUSTO_CLUSTER_URL = "https://cluster.kusto.windows.net"; - private static final String DATABASE = "testdb1"; - private static final String TABLE = "testtable1"; - private static final long fileThreshold = 100; - private static final long flushInterval = 5000; - private static final IngestClient mockClient = mock(IngestClient.class); - private static final TopicIngestionProperties propsCsv = new TopicIngestionProperties(); - private static final TopicPartition tp = new TopicPartition("testPartition", 11); - private static final long contextSwitchInterval = 200; - private static final IngestionProperties.DataFormat dataFormat = IngestionProperties.DataFormat.CSV; - private static KustoSinkConfig config; - // TODO: should probably find a better way to mock internal class (FileWriter)... - private File currentDirectory; - private String basePathCurrent; - private boolean isDlqEnabled; - private String dlqTopicName; - private Producer kafkaProducer; - private MockProducer dlqMockProducer; - - @BeforeAll - public static void beforeClass() { - propsCsv.ingestionProperties = new IngestionProperties(DATABASE, TABLE); - propsCsv.ingestionProperties.setDataFormat(dataFormat); - } - - @BeforeEach - public final void before() { - currentDirectory = Utils.getCurrentWorkingDirectory(); - Properties properties = new Properties(); - properties.put("bootstrap.servers", "localhost:9000"); - properties.put("key.serializer", "org.apache.kafka.common.serialization.ByteArraySerializer"); - properties.put("value.serializer", "org.apache.kafka.common.serialization.ByteArraySerializer"); - kafkaProducer = new KafkaProducer<>(properties); - isDlqEnabled = false; - dlqTopicName = null; - dlqMockProducer = new MockProducer<>( - true, new ByteArraySerializer(), new ByteArraySerializer()); - basePathCurrent = Paths.get(currentDirectory.getPath(), "testWriteStringyValuesAndOffset").toString(); - Map settings = getKustoConfigs(basePathCurrent, fileThreshold, flushInterval); - config = new KustoSinkConfig(settings); - } - - @AfterEach - public final void afterEach() { - FileUtils.deleteQuietly(currentDirectory); - } - - @Test - public void testHandleRollFile() { - IngestClient mockedClient = mock(IngestClient.class); - TopicIngestionProperties props = new TopicIngestionProperties(); - props.ingestionProperties = new IngestionProperties(DATABASE, TABLE); - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockedClient, props, config, isDlqEnabled, dlqTopicName, kafkaProducer); - SourceFile descriptor = new SourceFile(); - descriptor.rawBytes = 1024; - writer.handleRollFile(descriptor); - ArgumentCaptor fileSourceInfoArgument = ArgumentCaptor.forClass(FileSourceInfo.class); - ArgumentCaptor ingestionPropertiesArgumentCaptor = ArgumentCaptor.forClass(IngestionProperties.class); - try { - verify(mockedClient, only()).ingestFromFile(fileSourceInfoArgument.capture(), ingestionPropertiesArgumentCaptor.capture()); - } catch (Exception e) { - log.error("Error running testHandleRollFile", e); - fail(e); - } - - Assertions.assertEquals(fileSourceInfoArgument.getValue().getFilePath(), descriptor.path); - Assertions.assertEquals(TABLE, ingestionPropertiesArgumentCaptor.getValue().getTableName()); - Assertions.assertEquals(DATABASE, ingestionPropertiesArgumentCaptor.getValue().getDatabaseName()); - Assertions.assertEquals(1024, fileSourceInfoArgument.getValue().getRawSizeInBytes()); - } - - @Test - public void testHandleRollFileWithStreamingEnabled() { - IngestClient mockedClient = mock(IngestClient.class); - TopicIngestionProperties props = new TopicIngestionProperties(); - props.ingestionProperties = new IngestionProperties(DATABASE, TABLE); - props.streaming = true; - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockedClient, props, config, isDlqEnabled, dlqTopicName, kafkaProducer); - - SourceFile descriptor = new SourceFile(); - descriptor.rawBytes = 1024; - - writer.handleRollFile(descriptor); - ArgumentCaptor fileSourceInfoArgument = ArgumentCaptor.forClass(FileSourceInfo.class); - ArgumentCaptor ingestionPropertiesArgumentCaptor = ArgumentCaptor.forClass(IngestionProperties.class); - try { - verify(mockedClient, only()).ingestFromFile(fileSourceInfoArgument.capture(), ingestionPropertiesArgumentCaptor.capture()); - } catch (Exception e) { - log.error("Error running testHandleRollFile", e); - fail(e); - } - - Assertions.assertEquals(fileSourceInfoArgument.getValue().getFilePath(), descriptor.path); - Assertions.assertEquals(TABLE, ingestionPropertiesArgumentCaptor.getValue().getTableName()); - Assertions.assertEquals(DATABASE, ingestionPropertiesArgumentCaptor.getValue().getDatabaseName()); - Assertions.assertEquals(1024, fileSourceInfoArgument.getValue().getRawSizeInBytes()); - } - - @Test - public void testGetFilename() { - try { - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); - File writerFile = new File(writer.getFilePath(null)); - Assertions.assertEquals("kafka_testPartition_11_0.CSV.gz", writerFile.getName()); - } catch (Exception ex) { - // In case there is an accessor exception getting the file - fail(ex); - } - } - - @Test - public void testGetFilenameAfterOffsetChanges() { - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); - writer.open(); - List records = new ArrayList<>(); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 5)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); - for (SinkRecord record : records) { - writer.writeRecord(record); - } - try { - File writerFile = new File(writer.getFilePath(null)); - Assertions.assertTrue(writerFile.exists()); - Assertions.assertEquals("kafka_testPartition_11_5.CSV.gz", (new File(writer.getFilePath(null))).getName()); - } catch (Exception ex) { - // In case there is an accessor exception getting the file - fail(ex); - } - } - - @Test - public void testOpenClose() { - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); - writer.open(); - writer.close(); - } - - @Test - public void testWriteNonStringAndOffset() { - // String db = "testdb1"; - // String table = "testtable1"; - // - // TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, db, table, basePath, fileThreshold); - // - // List records = new ArrayList(); - // DummyRecord dummyRecord1 = new DummyRecord(1, "a", (long) 2); - // DummyRecord dummyRecord2 = new DummyRecord(2, "b", (long) 4); - // - // records.add(new SinkRecord("topic", 1, null, null, null, dummyRecord1, 10)); - // records.add(new SinkRecord("topic", 2, null, null, null, dummyRecord2, 3)); - // records.add(new SinkRecord("topic", 2, null, null, null, dummyRecord2, 4)); - // - // for (SinkRecord record : records) { - // writer.writeRecord(record); - // } - // - // Assert.assertEquals(writer.getFilePath(), "kafka_testPartition_11_0"); - } - - @Test - public void testWriteStringyValuesAndOffset() { - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); - - writer.open(); - List records = new ArrayList<>(); - - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 3)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); - - for (SinkRecord record : records) { - writer.writeRecord(record); - } - - Assertions.assertTrue((new File(writer.fileWriter.currentFile.path)).exists()); - Assertions.assertEquals(String.format("kafka_%s_%d_%d.%s.gz", tp.topic(), tp.partition(), 3, IngestionProperties.DataFormat.CSV.name()), - (new File(writer.fileWriter.currentFile.path)).getName()); - writer.close(); - } - - @Test - public void testWriteStringValuesAndOffset() throws IOException { - String[] messages = new String[] {"stringy message", "another,stringy,message", "{'also':'stringy','sortof':'message'}"}; - - // Expect to finish file after writing forth message cause of fileThreshold - long fileThreshold2 = messages[0].length() + messages[1].length() + messages[2].length() + messages[2].length() - 1; - Map settings2 = getKustoConfigs(basePathCurrent, fileThreshold2, flushInterval); - KustoSinkConfig config2 = new KustoSinkConfig(settings2); - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config2, isDlqEnabled, dlqTopicName, kafkaProducer); - - writer.open(); - List records = new ArrayList<>(); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[0], 10)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[1], 13)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[2], 14)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[2], 15)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[2], 16)); - - for (SinkRecord record : records) { - writer.writeRecord(record); - } - - Assertions.assertEquals(15, (long) writer.lastCommittedOffset); - Assertions.assertEquals(16, writer.currentOffset); - - String currentFileName = writer.fileWriter.currentFile.path; - Assertions.assertTrue(new File(currentFileName).exists()); - Assertions.assertEquals(String.format("kafka_%s_%d_%d.%s.gz", tp.topic(), tp.partition(), 15, IngestionProperties.DataFormat.CSV.name()), - (new File(currentFileName)).getName()); - - // Read - writer.fileWriter.finishFile(false); - Function assertFileConsumer = FileWriterTest.getAssertFileConsumerFunction(messages[2] + "\n"); - assertFileConsumer.apply(writer.fileWriter.currentFile); - writer.close(); - } - - @Test - public void testWriteBytesValuesAndOffset() throws IOException { - byte[] message = IOUtils.toByteArray( - Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream("data.avro"))); - ByteArrayOutputStream o = new ByteArrayOutputStream(); - o.write(message); - // Expect to finish file with one record although fileThreshold is high - long fileThreshold2 = 128; - TopicIngestionProperties propsAvro = new TopicIngestionProperties(); - propsAvro.ingestionProperties = new IngestionProperties(DATABASE, TABLE); - propsAvro.ingestionProperties.setDataFormat(IngestionProperties.DataFormat.AVRO); - Map settings2 = getKustoConfigs(basePathCurrent, fileThreshold2, flushInterval); - KustoSinkConfig config2 = new KustoSinkConfig(settings2); - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsAvro, config2, isDlqEnabled, dlqTopicName, kafkaProducer); - - writer.open(); - List records = new ArrayList<>(); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.BYTES_SCHEMA, o.toByteArray(), 10)); - - for (SinkRecord record : records) { - writer.writeRecord(record); - } - - Assertions.assertEquals(10, (long) writer.lastCommittedOffset); - Assertions.assertEquals(10, writer.currentOffset); - - String currentFileName = writer.fileWriter.currentFile.path; - - Assertions.assertTrue(new File(currentFileName).exists()); - Assertions.assertEquals(String.format("kafka_%s_%d_%d.%s.gz", tp.topic(), tp.partition(), 10, IngestionProperties.DataFormat.AVRO.name()), - (new File(currentFileName)).getName()); - writer.close(); - } - - @Test - public void testClose() throws InterruptedException { - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); - TopicPartitionWriter spyWriter = spy(writer); - - spyWriter.open(); - List records = new ArrayList<>(); - - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 5)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); - - for (SinkRecord record : records) { - spyWriter.writeRecord(record); - } - // 2 records are waiting to be ingested - expect close to revoke them so that even after 5 seconds it won't ingest - Assertions.assertNull(spyWriter.lastCommittedOffset); - spyWriter.close(); - Assertions.assertNull(spyWriter.lastCommittedOffset); - - Thread.sleep(flushInterval + contextSwitchInterval); - Assertions.assertNull(spyWriter.lastCommittedOffset); - } - - @Test - public void testSendFailedRecordToDlqError() { - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, true, "dlq.topic.name", kafkaProducer); - TopicPartitionWriter spyWriter = spy(writer); - // TODO this is to be re-worked - kafkaProducer = mock(Producer.class); - spyWriter.open(); - List records = new ArrayList<>(); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 5)); - records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); - when(kafkaProducer.send(any(), any())).thenReturn(null); - assertThrows(KafkaException.class, () -> spyWriter.sendFailedRecordToDlq(records.get(0))); - } - - @Test - public void testSendFailedRecordToDlqSuccess() { - TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, true, "dlq.topic.name", dlqMockProducer); - TopicPartitionWriter spyWriter = spy(writer); - - spyWriter.open(); - - SinkRecord testSinkRecord = new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4); - - byte[] recordKey = String.format("Failed to write record to KustoDB with the following kafka coordinates, " - + "topic=%s, partition=%s, offset=%s.", - testSinkRecord.topic(), - testSinkRecord.kafkaPartition(), - testSinkRecord.kafkaOffset()).getBytes(StandardCharsets.UTF_8); - byte[] recordValue = testSinkRecord.value().toString().getBytes(StandardCharsets.UTF_8); - ProducerRecord dlqRecord = new ProducerRecord<>("dlq.topic.name", recordKey, recordValue); - - // when(kafkaProducer.send(dlqRecord,anyObject())).thenReturn(null); - - dlqMockProducer.send(dlqRecord); - - List> history = dlqMockProducer.history(); - - List> expected = Collections.singletonList(dlqRecord); - - Assertions.assertEquals(expected, history); - - } - - private Map getKustoConfigs(String basePath, long fileThreshold, long flushInterval) { - Map settings = new HashMap<>(); - settings.put(KustoSinkConfig.KUSTO_INGEST_URL_CONF, KUSTO_INGEST_CLUSTER_URL); - settings.put(KustoSinkConfig.KUSTO_ENGINE_URL_CONF, KUSTO_CLUSTER_URL); - settings.put(KustoSinkConfig.KUSTO_TABLES_MAPPING_CONF, "mapping"); - settings.put(KustoSinkConfig.KUSTO_AUTH_APPID_CONF, "some-appid"); - settings.put(KustoSinkConfig.KUSTO_AUTH_APPKEY_CONF, "some-appkey"); - settings.put(KustoSinkConfig.KUSTO_AUTH_AUTHORITY_CONF, "some-authority"); - settings.put(KustoSinkConfig.KUSTO_SINK_TEMP_DIR_CONF, basePath); - settings.put(KustoSinkConfig.KUSTO_SINK_FLUSH_SIZE_BYTES_CONF, String.valueOf(fileThreshold)); - settings.put(KustoSinkConfig.KUSTO_SINK_FLUSH_INTERVAL_MS_CONF, String.valueOf(flushInterval)); - return settings; - } -} +package com.microsoft.azure.kusto.kafka.connect.sink; + +import java.io.ByteArrayOutputStream; +import java.io.File; +import java.io.IOException; +import java.nio.charset.StandardCharsets; +import java.nio.file.Paths; +import java.util.*; +import java.util.function.Function; + +import org.apache.commons.io.FileUtils; +import org.apache.commons.io.IOUtils; +import org.apache.kafka.clients.producer.KafkaProducer; +import org.apache.kafka.clients.producer.MockProducer; +import org.apache.kafka.clients.producer.Producer; +import org.apache.kafka.clients.producer.ProducerRecord; +import org.apache.kafka.common.KafkaException; +import org.apache.kafka.common.TopicPartition; +import org.apache.kafka.common.serialization.ByteArraySerializer; +import org.apache.kafka.connect.data.Schema; +import org.apache.kafka.connect.sink.SinkRecord; +import org.junit.jupiter.api.*; +import org.mockito.ArgumentCaptor; +import org.slf4j.Logger; +import org.slf4j.LoggerFactory; + +import com.microsoft.azure.kusto.ingest.IngestClient; +import com.microsoft.azure.kusto.ingest.IngestionProperties; +import com.microsoft.azure.kusto.ingest.source.FileSourceInfo; + +import static org.junit.jupiter.api.Assertions.assertThrows; +import static org.junit.jupiter.api.Assertions.fail; +import static org.mockito.Mockito.*; + +@Disabled +// TODO parts of this test needs to be re-formatted and may need rewriting +public class TopicPartitionWriterTest { + private static final Logger log = LoggerFactory.getLogger(TopicPartitionWriterTest.class); + + private static final String KUSTO_INGEST_CLUSTER_URL = "https://ingest-cluster.kusto.windows.net"; + private static final String KUSTO_CLUSTER_URL = "https://cluster.kusto.windows.net"; + private static final String DATABASE = "testdb1"; + private static final String TABLE = "testtable1"; + private static final long fileThreshold = 100; + private static final long flushInterval = 5000; + private static final IngestClient mockClient = mock(IngestClient.class); + private static final TopicIngestionProperties propsCsv = new TopicIngestionProperties(); + private static final TopicPartition tp = new TopicPartition("testPartition", 11); + private static final long contextSwitchInterval = 200; + private static KustoSinkConfig config; + // TODO: should probably find a better way to mock internal class (FileWriter)... + private File currentDirectory; + private String basePathCurrent; + private boolean isDlqEnabled; + private String dlqTopicName; + private Producer kafkaProducer; + private MockProducer dlqMockProducer; + + @BeforeAll + public static void beforeClass() { + propsCsv.ingestionProperties = new IngestionProperties(DATABASE, TABLE); + propsCsv.ingestionProperties.setDataFormat(IngestionProperties.DataFormat.JSON); + } + + @BeforeEach + public final void before() { + currentDirectory = Utils.getCurrentWorkingDirectory(); + Properties properties = new Properties(); + properties.put("bootstrap.servers", "localhost:9000"); + properties.put("key.serializer", "org.apache.kafka.common.serialization.ByteArraySerializer"); + properties.put("value.serializer", "org.apache.kafka.common.serialization.ByteArraySerializer"); + kafkaProducer = new KafkaProducer<>(properties); + isDlqEnabled = false; + dlqTopicName = null; + dlqMockProducer = new MockProducer<>( + true, new ByteArraySerializer(), new ByteArraySerializer()); + basePathCurrent = Paths.get(currentDirectory.getPath(), "testWriteStringyValuesAndOffset").toString(); + Map settings = getKustoConfigs(basePathCurrent, fileThreshold, flushInterval); + config = new KustoSinkConfig(settings); + } + + @AfterEach + public final void afterEach() { + FileUtils.deleteQuietly(currentDirectory); + } + + @Test + public void testHandleRollFile() { + IngestClient mockedClient = mock(IngestClient.class); + TopicIngestionProperties props = new TopicIngestionProperties(); + props.ingestionProperties = new IngestionProperties(DATABASE, TABLE); + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockedClient, props, config, isDlqEnabled, dlqTopicName, kafkaProducer); + SourceFile descriptor = new SourceFile(); + descriptor.rawBytes = 1024; + writer.handleRollFile(descriptor); + ArgumentCaptor fileSourceInfoArgument = ArgumentCaptor.forClass(FileSourceInfo.class); + ArgumentCaptor ingestionPropertiesArgumentCaptor = ArgumentCaptor.forClass(IngestionProperties.class); + try { + verify(mockedClient, only()).ingestFromFile(fileSourceInfoArgument.capture(), ingestionPropertiesArgumentCaptor.capture()); + } catch (Exception e) { + log.error("Error running testHandleRollFile", e); + fail(e); + } + + Assertions.assertEquals(fileSourceInfoArgument.getValue().getFilePath(), descriptor.path); + Assertions.assertEquals(TABLE, ingestionPropertiesArgumentCaptor.getValue().getTableName()); + Assertions.assertEquals(DATABASE, ingestionPropertiesArgumentCaptor.getValue().getDatabaseName()); + Assertions.assertEquals(1024, fileSourceInfoArgument.getValue().getRawSizeInBytes()); + } + + @Test + public void testHandleRollFileWithStreamingEnabled() { + IngestClient mockedClient = mock(IngestClient.class); + TopicIngestionProperties props = new TopicIngestionProperties(); + props.ingestionProperties = new IngestionProperties(DATABASE, TABLE); + props.streaming = true; + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockedClient, props, config, isDlqEnabled, dlqTopicName, kafkaProducer); + + SourceFile descriptor = new SourceFile(); + descriptor.rawBytes = 1024; + + writer.handleRollFile(descriptor); + ArgumentCaptor fileSourceInfoArgument = ArgumentCaptor.forClass(FileSourceInfo.class); + ArgumentCaptor ingestionPropertiesArgumentCaptor = ArgumentCaptor.forClass(IngestionProperties.class); + try { + verify(mockedClient, only()).ingestFromFile(fileSourceInfoArgument.capture(), ingestionPropertiesArgumentCaptor.capture()); + } catch (Exception e) { + log.error("Error running testHandleRollFile", e); + fail(e); + } + + Assertions.assertEquals(fileSourceInfoArgument.getValue().getFilePath(), descriptor.path); + Assertions.assertEquals(TABLE, ingestionPropertiesArgumentCaptor.getValue().getTableName()); + Assertions.assertEquals(DATABASE, ingestionPropertiesArgumentCaptor.getValue().getDatabaseName()); + Assertions.assertEquals(1024, fileSourceInfoArgument.getValue().getRawSizeInBytes()); + } + + @Test + public void testGetFilename() { + try { + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); + File writerFile = new File(writer.getFilePath(null)); + Assertions.assertEquals("kafka_testPartition_11_0.json.gz", writerFile.getName()); + } catch (Exception ex) { + // In case there is an accessor exception getting the file + fail(ex); + } + } + + @Test + public void testGetFilenameAfterOffsetChanges() { + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); + writer.open(); + List records = new ArrayList<>(); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 5)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); + for (SinkRecord record : records) { + writer.writeRecord(record); + } + try { + File writerFile = new File(writer.getFilePath(null)); + Assertions.assertTrue(writerFile.exists()); + Assertions.assertEquals("kafka_testPartition_11_4.json.gz", (new File(writer.getFilePath(null))).getName()); + } catch (Exception ex) { + // In case there is an accessor exception getting the file + fail(ex); + } + } + + @Test + public void testOpenClose() { + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); + writer.open(); + writer.close(); + } + + @Test + public void testWriteNonStringAndOffset() { + // String db = "testdb1"; + // String table = "testtable1"; + // + // TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, db, table, basePath, fileThreshold); + // + // List records = new ArrayList(); + // DummyRecord dummyRecord1 = new DummyRecord(1, "a", (long) 2); + // DummyRecord dummyRecord2 = new DummyRecord(2, "b", (long) 4); + // + // records.add(new SinkRecord("topic", 1, null, null, null, dummyRecord1, 10)); + // records.add(new SinkRecord("topic", 2, null, null, null, dummyRecord2, 3)); + // records.add(new SinkRecord("topic", 2, null, null, null, dummyRecord2, 4)); + // + // for (SinkRecord record : records) { + // writer.writeRecord(record); + // } + // + // Assert.assertEquals(writer.getFilePath(), "kafka_testPartition_11_0"); + } + + @Test + public void testWriteStringyValuesAndOffset() { + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); + writer.open(); + List records = new ArrayList<>(); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 3)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); + for (SinkRecord record : records) { + writer.writeRecord(record); + } + Assertions.assertTrue((new File(writer.fileWriter.currentFile.path)).exists()); + Assertions.assertEquals(String.format("kafka_%s_%d_%d.%s.gz", tp.topic(), tp.partition(), 4, + IngestionProperties.DataFormat.JSON.name().toLowerCase(Locale.ENGLISH)), + (new File(writer.fileWriter.currentFile.path)).getName()); + writer.close(); + } + + @Test + public void testWriteStringValuesAndOffset() throws IOException { + String[] messages = new String[] {"stringy message", "another,stringy,message", "{'also':'stringy','sortof':'message'}"}; + + // Expect to finish file after writing forth message cause of fileThreshold + long fileThreshold2 = messages[0].length() + messages[1].length() + messages[2].length() + messages[2].length() - 1; + Map settings2 = getKustoConfigs(basePathCurrent, fileThreshold2, flushInterval); + KustoSinkConfig config2 = new KustoSinkConfig(settings2); + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config2, isDlqEnabled, dlqTopicName, kafkaProducer); + + writer.open(); + List records = new ArrayList<>(); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[0], 10)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[1], 13)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[2], 14)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[2], 15)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, messages[2], 16)); + + for (SinkRecord record : records) { + writer.writeRecord(record); + } + + Assertions.assertEquals(16, (long) writer.lastCommittedOffset); + Assertions.assertEquals(16, writer.currentOffset); + + String currentFileName = writer.fileWriter.currentFile.path; + Assertions.assertTrue(new File(currentFileName).exists()); + Assertions.assertEquals(String.format("kafka_%s_%d_%d.%s.gz", tp.topic(), + tp.partition(), 16, IngestionProperties.DataFormat.JSON.name().toLowerCase(Locale.ENGLISH)), + (new File(currentFileName)).getName()); + + // Read + writer.fileWriter.finishFile(false); + Function assertFileConsumer = FileWriterTest.getAssertFileConsumerFunction(messages[2] + "\n"); + assertFileConsumer.apply(writer.fileWriter.currentFile); + writer.close(); + } + + @Test + public void testWriteBytesValuesAndOffset() throws IOException { + byte[] message = IOUtils.toByteArray( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream("data.avro"))); + ByteArrayOutputStream o = new ByteArrayOutputStream(); + o.write(message); + // Expect to finish file with one record although fileThreshold is high + long fileThreshold2 = 128; + TopicIngestionProperties propsAvro = new TopicIngestionProperties(); + propsAvro.ingestionProperties = new IngestionProperties(DATABASE, TABLE); + propsAvro.ingestionProperties.setDataFormat(IngestionProperties.DataFormat.AVRO); + Map settings2 = getKustoConfigs(basePathCurrent, fileThreshold2, flushInterval); + KustoSinkConfig config2 = new KustoSinkConfig(settings2); + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsAvro, config2, isDlqEnabled, dlqTopicName, kafkaProducer); + + writer.open(); + List records = new ArrayList<>(); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.BYTES_SCHEMA, o.toByteArray(), 10)); + + for (SinkRecord record : records) { + writer.writeRecord(record); + } + + Assertions.assertEquals(10, (long) writer.lastCommittedOffset); + Assertions.assertEquals(10, writer.currentOffset); + + String currentFileName = writer.fileWriter.currentFile.path; + + Assertions.assertTrue(new File(currentFileName).exists()); + Assertions.assertEquals(String.format("kafka_%s_%d_%d.%s.gz", tp.topic(), tp.partition(), + 10, IngestionProperties.DataFormat.JSON.name().toLowerCase(Locale.ENGLISH)), + (new File(currentFileName)).getName()); + writer.close(); + } + + @Test + public void testClose() throws InterruptedException { + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, isDlqEnabled, dlqTopicName, kafkaProducer); + TopicPartitionWriter spyWriter = spy(writer); + + spyWriter.open(); + List records = new ArrayList<>(); + + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 5)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); + + for (SinkRecord record : records) { + spyWriter.writeRecord(record); + } + // 2 records are waiting to be ingested - expect close to revoke them so that even after 5 seconds it won't ingest + Assertions.assertNotNull(spyWriter.lastCommittedOffset); + spyWriter.close(); + Thread.sleep(flushInterval + contextSwitchInterval); + Assertions.assertNotNull(spyWriter.lastCommittedOffset); + } + + @Disabled + @Test + public void testSendFailedRecordToDlqError() { + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, true, "dlq.topic.name", kafkaProducer); + TopicPartitionWriter spyWriter = spy(writer); + // TODO this is to be re-worked + kafkaProducer = mock(Producer.class); + spyWriter.open(); + List records = new ArrayList<>(); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "another,stringy,message", 5)); + records.add(new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4)); + when(kafkaProducer.send(any(), any())).thenReturn(null); + assertThrows(KafkaException.class, () -> spyWriter.sendFailedRecordToDlq(records.get(0))); + } + + @Disabled + @Test + public void testSendFailedRecordToDlqSuccess() { + TopicPartitionWriter writer = new TopicPartitionWriter(tp, mockClient, propsCsv, config, true, "dlq.topic.name", dlqMockProducer); + TopicPartitionWriter spyWriter = spy(writer); + + spyWriter.open(); + + SinkRecord testSinkRecord = new SinkRecord(tp.topic(), tp.partition(), null, null, Schema.STRING_SCHEMA, "{'also':'stringy','sortof':'message'}", 4); + + byte[] recordKey = String.format("Failed to write record to KustoDB with the following kafka coordinates, " + + "topic=%s, partition=%s, offset=%s.", + testSinkRecord.topic(), + testSinkRecord.kafkaPartition(), + testSinkRecord.kafkaOffset()).getBytes(StandardCharsets.UTF_8); + byte[] recordValue = testSinkRecord.value().toString().getBytes(StandardCharsets.UTF_8); + ProducerRecord dlqRecord = new ProducerRecord<>("dlq.topic.name", recordKey, recordValue); + + // when(kafkaProducer.send(dlqRecord,anyObject())).thenReturn(null); + + dlqMockProducer.send(dlqRecord); + + List> history = dlqMockProducer.history(); + + List> expected = Collections.singletonList(dlqRecord); + + Assertions.assertEquals(expected, history); + + } + + private Map getKustoConfigs(String basePath, long fileThreshold, long flushInterval) { + Map settings = new HashMap<>(); + settings.put(KustoSinkConfig.KUSTO_INGEST_URL_CONF, KUSTO_INGEST_CLUSTER_URL); + settings.put(KustoSinkConfig.KUSTO_ENGINE_URL_CONF, KUSTO_CLUSTER_URL); + settings.put(KustoSinkConfig.KUSTO_TABLES_MAPPING_CONF, "mapping"); + settings.put(KustoSinkConfig.KUSTO_AUTH_APPID_CONF, "some-appid"); + settings.put(KustoSinkConfig.KUSTO_AUTH_APPKEY_CONF, "some-appkey"); + settings.put(KustoSinkConfig.KUSTO_AUTH_AUTHORITY_CONF, "some-authority"); + settings.put(KustoSinkConfig.KUSTO_SINK_TEMP_DIR_CONF, basePath); + settings.put(KustoSinkConfig.KUSTO_SINK_FLUSH_SIZE_BYTES_CONF, String.valueOf(fileThreshold)); + settings.put(KustoSinkConfig.KUSTO_SINK_FLUSH_INTERVAL_MS_CONF, String.valueOf(flushInterval)); + return settings; + } +} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/AvroRecordWriterTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/AvroRecordWriterTest.java deleted file mode 100644 index 4676ebf0..00000000 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/AvroRecordWriterTest.java +++ /dev/null @@ -1,66 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.File; -import java.io.IOException; -import java.io.OutputStream; -import java.nio.file.Files; -import java.util.ArrayList; -import java.util.List; - -import org.apache.avro.file.DataFileReader; -import org.apache.avro.generic.GenericData; -import org.apache.avro.generic.GenericDatumReader; -import org.apache.commons.io.FileUtils; -import org.apache.kafka.connect.data.Schema; -import org.apache.kafka.connect.data.SchemaBuilder; -import org.apache.kafka.connect.data.Struct; -import org.apache.kafka.connect.sink.SinkRecord; -import org.junit.jupiter.api.Test; - -import com.microsoft.azure.kusto.kafka.connect.sink.Utils; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; - -import static org.junit.jupiter.api.Assertions.assertEquals; - -public class AvroRecordWriterTest { - @Test - public void AvroDataWrite() throws IOException { - List records = new ArrayList<>(); - final Schema schema = SchemaBuilder.struct() - .field("text", SchemaBuilder.string().build()) - .field("id", SchemaBuilder.int32().build()) - .build(); - - for (int i = 0; i < 10; i++) { - final Struct struct = new Struct(schema) - .put("text", String.format("record-%s", i)) - .put("id", i); - records.add(new SinkRecord("mytopic", 0, null, null, schema, struct, 10)); - } - File file = new File("abc.avro"); - Utils.restrictPermissions(file); - AvroRecordWriterProvider writer = new AvroRecordWriterProvider(); - OutputStream out = Files.newOutputStream(file.toPath()); - RecordWriter rd = writer.getRecordWriter(file.getPath(), out); - for (SinkRecord record : records) { - rd.write(record); - } - rd.commit(); - validate(file.getPath()); - FileUtils.deleteQuietly(file); - } - - public void validate(String path) throws IOException { - // Warns if the types are not generified - GenericDatumReader datum = new GenericDatumReader<>(); - File file = new File(path); - DataFileReader reader = new DataFileReader<>(file, datum); - GenericData.Record record = new GenericData.Record(reader.getSchema()); - int i = 0; - while (reader.hasNext()) { - assertEquals(reader.next(record).toString(), String.format("{\"text\": \"record-%s\", \"id\": %s}", i, i)); - i++; - } - reader.close(); - } -} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/ByteArrayWriterProviderTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/ByteArrayWriterProviderTest.java deleted file mode 100644 index 4d289c96..00000000 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/ByteArrayWriterProviderTest.java +++ /dev/null @@ -1,50 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.BufferedReader; -import java.io.File; -import java.io.FileReader; -import java.io.IOException; -import java.io.OutputStream; -import java.nio.file.Files; -import java.util.ArrayList; -import java.util.List; - -import org.apache.commons.io.FileUtils; -import org.apache.kafka.connect.data.Schema; -import org.apache.kafka.connect.sink.SinkRecord; -import org.junit.jupiter.api.Test; - -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; - -import static com.microsoft.azure.kusto.kafka.connect.sink.Utils.restrictPermissions; -import static org.junit.jupiter.api.Assertions.assertEquals; - -public class ByteArrayWriterProviderTest { - @Test - public void testByteData() throws IOException { - List records = new ArrayList<>(); - for (int i = 0; i < 10; i++) { - records.add(new SinkRecord("mytopic", 0, null, null, Schema.BYTES_SCHEMA, - String.format("hello-%s", i).getBytes(), i)); - } - File file = new File("abc.bin"); - restrictPermissions(file); - file.deleteOnExit(); - try (OutputStream out = Files.newOutputStream(file.toPath()); - BufferedReader br = new BufferedReader(new FileReader(file))) { - ByteRecordWriterProvider writer = new ByteRecordWriterProvider(); - RecordWriter rd = writer.getRecordWriter(file.getPath(), out); - for (SinkRecord record : records) { - rd.write(record); - } - rd.commit(); - String st; - int i = 0; - while ((st = br.readLine()) != null) { - assertEquals(st, String.format("hello-%s", i)); - i++; - } - } - FileUtils.deleteQuietly(file); - } -} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/JsonRecordWriterProviderTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/JsonRecordWriterProviderTest.java deleted file mode 100644 index 0f4ea6de..00000000 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/JsonRecordWriterProviderTest.java +++ /dev/null @@ -1,53 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.BufferedReader; -import java.io.File; -import java.io.FileReader; -import java.io.IOException; -import java.io.OutputStream; -import java.nio.file.Files; -import java.util.ArrayList; -import java.util.HashMap; -import java.util.List; -import java.util.Map; - -import org.apache.commons.io.FileUtils; -import org.apache.kafka.connect.sink.SinkRecord; -import org.junit.jupiter.api.Test; - -import com.microsoft.azure.kusto.kafka.connect.sink.Utils; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; - -import static org.junit.jupiter.api.Assertions.assertEquals; - -// TODO: Significant duplication among these 4 classes -public class JsonRecordWriterProviderTest { - @Test - public void testJsonData() throws IOException { - List records = new ArrayList<>(); - for (int i = 0; i < 10; i++) { - Map map = new HashMap<>(); - map.put("hello", i); - records.add(new SinkRecord("mytopic", 0, null, null, null, map, i)); - } - File file = new File("abc.json"); - file.deleteOnExit(); - Utils.restrictPermissions(file); - JsonRecordWriterProvider jsonWriter = new JsonRecordWriterProvider(); - try (OutputStream out = Files.newOutputStream(file.toPath()); - BufferedReader br = new BufferedReader(new FileReader(file))) { - RecordWriter rd = jsonWriter.getRecordWriter(file.getPath(), out); - for (SinkRecord record : records) { - rd.write(record); - } - rd.commit(); - String st; - int i = 0; - while ((st = br.readLine()) != null) { - assertEquals(st, String.format("{\"hello\":%s}", i)); - i++; - } - FileUtils.deleteQuietly(file); - } - } -} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/StringRecordWriterProviderTest.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/StringRecordWriterProviderTest.java deleted file mode 100644 index 8539bed9..00000000 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatWriter/StringRecordWriterProviderTest.java +++ /dev/null @@ -1,49 +0,0 @@ -package com.microsoft.azure.kusto.kafka.connect.sink.formatWriter; - -import java.io.BufferedReader; -import java.io.File; -import java.io.FileReader; -import java.io.IOException; -import java.io.OutputStream; -import java.nio.file.Files; -import java.util.ArrayList; -import java.util.List; - -import org.apache.commons.io.FileUtils; -import org.apache.kafka.connect.data.Schema; -import org.apache.kafka.connect.sink.SinkRecord; -import org.junit.jupiter.api.Test; - -import com.microsoft.azure.kusto.kafka.connect.sink.Utils; -import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; - -import static org.junit.jupiter.api.Assertions.assertEquals; - -public class StringRecordWriterProviderTest { - @Test - public void testStringData() throws IOException { - List records = new ArrayList<>(); - for (int i = 0; i < 10; i++) { - records.add( - new SinkRecord("mytopic", 0, null, null, Schema.STRING_SCHEMA, String.format("hello-%s", i), i)); - } - File file = new File("abc.txt"); - Utils.restrictPermissions(file); - try (OutputStream out = Files.newOutputStream(file.toPath()); - BufferedReader br = new BufferedReader(new FileReader(file))) { - StringRecordWriterProvider writer = new StringRecordWriterProvider(); - RecordWriter rd = writer.getRecordWriter(file.getPath(), out); - for (SinkRecord record : records) { - rd.write(record); - } - rd.commit(); - String st; - int i = 0; - while ((st = br.readLine()) != null) { - assertEquals(st, String.format("hello-%s", i)); - i++; - } - } - FileUtils.deleteQuietly(file); - } -} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterBase.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterBase.java new file mode 100644 index 00000000..d95d417b --- /dev/null +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterBase.java @@ -0,0 +1,49 @@ +package com.microsoft.azure.kusto.kafka.connect.sink.formatwriter; + +import java.io.IOException; +import java.nio.file.Files; +import java.nio.file.Paths; +import java.util.List; +import java.util.Map; + +import org.json.JSONException; +import org.junit.jupiter.api.Assertions; +import org.skyscreamer.jsonassert.JSONAssert; + +import com.fasterxml.jackson.core.type.TypeReference; +import com.fasterxml.jackson.databind.ObjectMapper; +import com.fasterxml.jackson.databind.SerializationFeature; + +public abstract class KustoRecordWriterBase { + protected static final String KEYS = "keys"; + protected static final String HEADERS = "headers"; + protected static final String KAFKA_MD = "kafkamd"; + protected static final ObjectMapper RESULT_MAPPER = new ObjectMapper().disable(SerializationFeature.FAIL_ON_EMPTY_BEANS); + protected static final TypeReference> GENERIC_MAP = new TypeReference>() {}; + + protected void validate(String actualFilePath, Map expectedResultsMap) throws IOException, JSONException { + // Warns if the types are not generified + List actualJson = Files.readAllLines(Paths.get(actualFilePath)); + for (int i = 0; i < actualJson.size(); i++) { + String actual = actualJson.get(i); + Map actualMap = RESULT_MAPPER.readValue(actual, GENERIC_MAP); + String[] expected = expectedResultsMap.get(i); + String actualKeys = RESULT_MAPPER.writeValueAsString(actualMap.get(KEYS)); + String actualHeaders = RESULT_MAPPER.writeValueAsString(actualMap.get(HEADERS)); + JSONAssert.assertEquals(expected[1], actualKeys, false); + JSONAssert.assertEquals(expected[0], actualHeaders, false); + // to get the values it is to remove keys and headers , then get all the fields and compare + actualMap.remove(KEYS); + actualMap.remove(HEADERS); + actualMap.remove(KAFKA_MD); + // Now actualMap contains only the value + String actualValues = RESULT_MAPPER.writeValueAsString(actualMap); + if (expected[2] == null) { + // there are no fields or no keys + Assertions.assertTrue(actualMap.keySet().isEmpty(), "Expected null value for tombstone record"); + } else { + JSONAssert.assertEquals(expected[2], actualValues, false); + } + } + } +} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterSchemaTests.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterSchemaTests.java new file mode 100644 index 00000000..33c78613 --- /dev/null +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterSchemaTests.java @@ -0,0 +1,198 @@ +package com.microsoft.azure.kusto.kafka.connect.sink.formatwriter; + +import java.io.File; +import java.io.IOException; +import java.io.OutputStream; +import java.nio.file.Files; +import java.util.*; +import java.util.stream.Stream; + +import org.apache.avro.generic.GenericData; +import org.apache.commons.io.FileUtils; +import org.apache.kafka.connect.data.Schema; +import org.apache.kafka.connect.data.SchemaBuilder; +import org.apache.kafka.connect.sink.SinkRecord; +import org.jetbrains.annotations.NotNull; +import org.json.JSONException; +import org.junit.jupiter.params.ParameterizedTest; +import org.junit.jupiter.params.provider.Arguments; +import org.junit.jupiter.params.provider.CsvSource; +import org.junit.jupiter.params.provider.MethodSource; + +import com.microsoft.azure.kusto.ingest.IngestionProperties; +import com.microsoft.azure.kusto.kafka.connect.sink.Utils; +import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; + +import io.confluent.avro.random.generator.Generator; +import io.confluent.connect.avro.AvroData; +import tech.allegro.schema.json2avro.converter.JsonAvroConverter; + +public class KustoRecordWriterSchemaTests extends KustoRecordWriterBase { + private static @NotNull Stream testMapSchemaJson() { + // Key schema, value schema, expectedKey, expectedValue + Schema intToIntSchema = SchemaBuilder.map(Schema.INT32_SCHEMA, Schema.INT32_SCHEMA).name("IntToIntMap").build(); + Schema stringToIntSchema = SchemaBuilder.map(Schema.STRING_SCHEMA, Schema.INT32_SCHEMA).name("StringToIntMap").build(); + Schema stringToOptionalIntSchema = SchemaBuilder.map(Schema.STRING_SCHEMA, Schema.OPTIONAL_INT32_SCHEMA).name("StringToOptionalInt").build(); + Schema arrayOfInts = SchemaBuilder.array(Schema.INT32_SCHEMA).name("ArrayOfInts").build(); + Schema simpleLongSchema = SchemaBuilder.struct().field("recordKey", Schema.INT64_SCHEMA).name("SimpleLongSchema").build(); + Schema structSchema = SchemaBuilder.struct().field("field1", Schema.BOOLEAN_SCHEMA) + .field("field2", Schema.STRING_SCHEMA).name("StructSchema").build(); + + Map intToIntMap = Collections.singletonMap(0, 12); + Map stringToIntMap = Collections.singletonMap("String-42", 32); + Map stringToOptionalIntMap = Collections.singletonMap("NullString-42", null); + Map stringToOptionalIntMapMultiple = new HashMap<>(); + stringToOptionalIntMapMultiple.put("NullString-42", null); + stringToOptionalIntMapMultiple.put("String-42", 32); + + return Stream.of( + Arguments.of(intToIntSchema, stringToIntSchema, intToIntMap, stringToIntMap, false, false), + Arguments.of(stringToIntSchema, stringToOptionalIntSchema, stringToIntMap, stringToOptionalIntMap, false, false), + Arguments.of(stringToIntSchema, stringToOptionalIntSchema, stringToIntMap, stringToOptionalIntMapMultiple, false, false), + Arguments.of(stringToIntSchema, arrayOfInts, stringToIntMap, new Integer[] {1, 2, 3, 5, 8, 13, 21}, false, true), + Arguments.of(simpleLongSchema, structSchema, Collections.singletonMap("recordKey", 42L), + "{\"field1\":true,\"field2\":\"Field-@42\"}", false, false), + Arguments.of(simpleLongSchema, structSchema, Collections.singletonMap("recordKey", 42L), null, false, false)); + } + + @ParameterizedTest(name = "AVRO Data to be serialized with key schema {0} and value schema {1} isSimpleKey {2} isSimpleValue {3}") + @CsvSource({ + "avro-simple-schema.json,avro-struct-schema.json,true,false", + "avro-struct-schema.json,avro-struct-schema.json,false,false", + "avro-simple-schema.json,avro-simple-schema.json,true,true" + }) + public void validateAvroDataToBeSerialized(String keySchemaPath, String valueSchemaPath, boolean isSimpleKey, boolean isSimpleValue) + throws IOException, JSONException { + List records = new ArrayList<>(); + Generator randomAvroValueData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", valueSchemaPath)))).build(); + Generator randomAvroKeyData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", keySchemaPath)))).build(); + AvroData avroDataCache = new AvroData(50); + Schema keySchema = avroDataCache.toConnectSchema(randomAvroKeyData.schema()); + Schema valueSchema = avroDataCache.toConnectSchema(randomAvroValueData.schema()); + JsonAvroConverter converter = new JsonAvroConverter(); + Map expectedResultsMap = new HashMap<>(); + for (int i = 0; i < 10; i++) { + Object key = randomAvroKeyData.generate(); + Object value = randomAvroValueData.generate(); + SinkRecord sinkRecord = new SinkRecord("avro.record.topic", i % 3, + keySchema, + key, + valueSchema, + value, + i); + sinkRecord.headers().addInt(String.format("HeaderInt-%s", i), i); + records.add(sinkRecord); + String expectedValueString = isSimpleValue ? RESULT_MAPPER.writeValueAsString(Collections.singletonMap("value", value)) + : new String(converter.convertToJson((GenericData.Record) value)); + String expectedKeyString = isSimpleKey ? key.toString() : new String(converter.convertToJson((GenericData.Record) key)); + String expectedHeaderJson = RESULT_MAPPER.writeValueAsString(Collections.singletonMap(String.format("HeaderInt-%s", i), i)); + expectedResultsMap.put(i, new String[] {expectedHeaderJson, expectedKeyString, expectedValueString}); + } + File file = new File(String.format("%s.%s", UUID.randomUUID(), "json")); + Utils.restrictPermissions(file); + KustoRecordWriterProvider writer = new KustoRecordWriterProvider(); + OutputStream out = Files.newOutputStream(file.toPath()); + RecordWriter rd = writer.getRecordWriter(file.getPath(), out); + for (SinkRecord record : records) { + rd.write(record, IngestionProperties.DataFormat.AVRO); + } + rd.commit(); + validate(file.getPath(), expectedResultsMap); + rd.close(); + FileUtils.deleteQuietly(file); + } + + // Idea is to use Avro Schema to generate Avro data and convert them to random JSON for tests + @ParameterizedTest(name = "JSON Data to be serialized with key schema {0} and value schema {1} isSimpleKey {2} isSimpleValue {3}") + @CsvSource({ + "avro-simple-schema.json,avro-struct-schema.json,true,false", + "avro-struct-schema.json,avro-struct-schema.json,false,false", + "avro-simple-schema.json,avro-simple-schema.json,true,true" + }) + public void validateJsonDataToBeSerialized(String keySchemaPath, String valueSchemaPath, boolean isSimpleKey, boolean isSimpleValue) + throws IOException, JSONException { + List records = new ArrayList<>(); + Generator randomAvroValueData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", valueSchemaPath)))).build(); + Generator randomAvroKeyData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", keySchemaPath)))).build(); + + Map expectedResultsMap = new HashMap<>(); + for (int i = 0; i < 10; i++) { + Object key = randomAvroKeyData.generate().toString(); + Object value = randomAvroValueData.generate().toString(); + SinkRecord sinkRecord = new SinkRecord("json.record.topic", i % 3, + null, + key, + null, + value, + i); + sinkRecord.headers().addInt(String.format("HeaderInt-%s", i), i); + records.add(sinkRecord); + + String expectedValueString = isSimpleValue ? RESULT_MAPPER.writeValueAsString(Collections.singletonMap("value", value)) : value.toString(); + String expectedKeyString = isSimpleKey ? RESULT_MAPPER.writeValueAsString(key) : key.toString(); + String expectedHeaderJson = RESULT_MAPPER.writeValueAsString(Collections.singletonMap(String.format("HeaderInt-%s", i), i)); + expectedResultsMap.put(i, new String[] {expectedHeaderJson, expectedKeyString, expectedValueString}); + } + File file = new File(String.format("%s.%s", UUID.randomUUID(), "json")); + Utils.restrictPermissions(file); + KustoRecordWriterProvider writer = new KustoRecordWriterProvider(); + OutputStream out = Files.newOutputStream(file.toPath()); + RecordWriter rd = writer.getRecordWriter(file.getPath(), out); + for (SinkRecord record : records) { + rd.write(record, IngestionProperties.DataFormat.JSON); + } + rd.commit(); + validate(file.getPath(), expectedResultsMap); + rd.close(); + FileUtils.deleteQuietly(file); + } + + @ParameterizedTest(name = "Map Data to be serialized with key schema {0}.name() and value schema {1}.name()") + @MethodSource("testMapSchemaJson") + public void collectionsSerializationTests(Schema keySchema, Schema valueSchema, + Map keyValues, Object expectedValues, + boolean isSimpleKey, boolean isSimpleValue) throws IOException, JSONException { + // Set up + Map expectedResultsMap = new HashMap<>(); + SinkRecord sinkRecord = new SinkRecord("json.map.record.topic", 0, + keySchema, + keyValues, + valueSchema, + expectedValues, + 0); + sinkRecord.headers().addInt(String.format("HeaderInt-%s", 0), 0); + String expectedKeyString = isSimpleKey ? RESULT_MAPPER.writeValueAsString(Collections.singletonMap("key", keyValues)) + : RESULT_MAPPER.writeValueAsString(keyValues); + // Sometimes the input is a JSON string. No need to double encode. Check the struct test + String expectedValueString; + if (expectedValues == null) { + expectedValueString = null; + } else if (expectedValues instanceof String) { + expectedValueString = expectedValues.toString(); + } else if (isSimpleValue) { + expectedValueString = RESULT_MAPPER.writeValueAsString(Collections.singletonMap("value", expectedValues)); + } else { + expectedValueString = RESULT_MAPPER.writeValueAsString(expectedValues); + } + String expectedHeaderJson = RESULT_MAPPER.writeValueAsString( + Collections.singletonMap(String.format("HeaderInt-%s", 0), 0)); + expectedResultsMap.put(0, new String[] {expectedHeaderJson, expectedKeyString, expectedValueString}); + + // Act + File file = new File(String.format("%s.%s", UUID.randomUUID(), "json")); + Utils.restrictPermissions(file); + KustoRecordWriterProvider writer = new KustoRecordWriterProvider(); + OutputStream out = Files.newOutputStream(file.toPath()); + RecordWriter rd = writer.getRecordWriter(file.getPath(), out); + rd.write(sinkRecord, IngestionProperties.DataFormat.JSON); + // verify + validate(file.getPath(), expectedResultsMap); + rd.commit(); + rd.close(); + FileUtils.deleteQuietly(file); + } +} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterSchemalessTests.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterSchemalessTests.java new file mode 100644 index 00000000..a43900ea --- /dev/null +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/formatwriter/KustoRecordWriterSchemalessTests.java @@ -0,0 +1,122 @@ +package com.microsoft.azure.kusto.kafka.connect.sink.formatwriter; + +import java.io.File; +import java.io.IOException; +import java.io.OutputStream; +import java.nio.charset.StandardCharsets; +import java.nio.file.Files; +import java.util.*; + +import org.apache.avro.generic.GenericData; +import org.apache.avro.generic.GenericRecord; +import org.apache.commons.io.FileUtils; +import org.apache.kafka.connect.sink.SinkRecord; +import org.json.JSONException; +import org.junit.jupiter.params.ParameterizedTest; +import org.junit.jupiter.params.provider.CsvSource; + +import com.microsoft.azure.kusto.ingest.IngestionProperties; +import com.microsoft.azure.kusto.kafka.connect.sink.Utils; +import com.microsoft.azure.kusto.kafka.connect.sink.format.RecordWriter; + +import io.confluent.avro.random.generator.Generator; +import tech.allegro.schema.json2avro.converter.JsonAvroConverter; + +public class KustoRecordWriterSchemalessTests extends KustoRecordWriterBase { + @ParameterizedTest(name = "JSON data serialized as bytes with key schema {0} and " + + "value schema {1} should be deserialized correctly. Simple key: {2}, Simple value: {3}") + @CsvSource({ + "avro-simple-schema.json,avro-struct-schema.json,true,false", + "avro-struct-schema.json,avro-struct-schema.json,false,false", + "avro-simple-schema.json,avro-simple-schema.json,true,true" + }) + public void validateJsonSerializedAsBytes(String keySchemaPath, String valueSchemaPath, + boolean isSimpleKey, boolean isSimpleValue) + throws IOException, JSONException { + List records = new ArrayList<>(); + Generator randomAvroValueData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", valueSchemaPath)))).build(); + Generator randomAvroKeyData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", keySchemaPath)))).build(); + JsonAvroConverter converter = new JsonAvroConverter(); + Map expectedResultsMap = new HashMap<>(); + for (int i = 0; i < 10; i++) { + Object avroKey = randomAvroKeyData.generate(); + Object key = avroKey.toString().getBytes(StandardCharsets.UTF_8); + Object avroValue = randomAvroValueData.generate(); + Object value = avroValue.toString().getBytes(StandardCharsets.UTF_8); + SinkRecord sinkRecord = new SinkRecord("bytes.record.topic", i % 3, + null, + key, + null, + value, + i); + sinkRecord.headers().addInt(String.format("HeaderInt-%s", i), i); + records.add(sinkRecord); + String expectedValueString = isSimpleValue ? RESULT_MAPPER.writeValueAsString(Collections.singletonMap("value", avroValue)) + : new String(converter.convertToJson((GenericRecord) avroValue), StandardCharsets.UTF_8); + String expectedKeyString = isSimpleKey ? avroKey.toString() : new String(converter.convertToJson((GenericRecord) avroKey), StandardCharsets.UTF_8); + String expectedHeaderJson = RESULT_MAPPER.writeValueAsString(Collections.singletonMap( + String.format("HeaderInt-%s", i), i)); + expectedResultsMap.put(i, new String[] {expectedHeaderJson, expectedKeyString, expectedValueString}); + } + File file = new File(String.format("%s.%s", UUID.randomUUID(), "json")); + Utils.restrictPermissions(file); + KustoRecordWriterProvider writer = new KustoRecordWriterProvider(); + OutputStream out = Files.newOutputStream(file.toPath()); + RecordWriter rd = writer.getRecordWriter(file.getPath(), out); + for (SinkRecord record : records) { + rd.write(record, IngestionProperties.DataFormat.JSON); + } + rd.commit(); + validate(file.getPath(), expectedResultsMap); + rd.close(); + FileUtils.deleteQuietly(file); + } + + @ParameterizedTest(name = "AVRO Data to be serialized with key schema {0} and value schema {1} isSimpleKey {2} isSimpleValue {3}") + @CsvSource({ + "avro-simple-schema.json,avro-struct-schema.json,true,false", + "avro-struct-schema.json,avro-struct-schema.json,false,false", + "avro-simple-schema.json,avro-simple-schema.json,true,true" + }) + public void validateAvroDataSerializedAsBytes(String keySchemaPath, String valueSchemaPath, boolean isSimpleKey, boolean isSimpleValue) + throws IOException, JSONException { + List records = new ArrayList<>(); + Generator randomAvroValueData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", valueSchemaPath)))).build(); + Generator randomAvroKeyData = new Generator.Builder().schemaStream( + Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-schemas/%s", keySchemaPath)))).build(); + JsonAvroConverter converter = new JsonAvroConverter(); + Map expectedResultsMap = new HashMap<>(); + for (int i = 0; i < 10; i++) { + Object key = randomAvroKeyData.generate(); + Object value = randomAvroValueData.generate(); + SinkRecord sinkRecord = new SinkRecord("avro.bytes.record.topic", i % 3, + null, + key, + null, + value, + i); + sinkRecord.headers().addInt(String.format("HeaderInt-%s", i), i); + records.add(sinkRecord); + String expectedValueString = isSimpleValue ? RESULT_MAPPER.writeValueAsString(Collections.singletonMap("value", value)) + : new String(converter.convertToJson((GenericData.Record) value)); + String expectedKeyString = isSimpleKey ? key.toString() : new String(converter.convertToJson((GenericData.Record) key)); + String expectedHeaderJson = RESULT_MAPPER.writeValueAsString(Collections.singletonMap(String.format("HeaderInt-%s", i), i)); + expectedResultsMap.put(i, new String[] {expectedHeaderJson, expectedKeyString, expectedValueString}); + } + File file = new File(String.format("%s.%s", UUID.randomUUID(), "json")); + Utils.restrictPermissions(file); + KustoRecordWriterProvider writer = new KustoRecordWriterProvider(); + OutputStream out = Files.newOutputStream(file.toPath()); + RecordWriter rd = writer.getRecordWriter(file.getPath(), out); + for (SinkRecord record : records) { + rd.write(record, IngestionProperties.DataFormat.AVRO); + } + rd.commit(); + validate(file.getPath(), expectedResultsMap); + rd.close(); + FileUtils.deleteQuietly(file); + } +} diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/KustoSinkIT.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/KustoSinkIT.java index b4d90723..8c247fd1 100644 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/KustoSinkIT.java +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/KustoSinkIT.java @@ -1,34 +1,39 @@ package com.microsoft.azure.kusto.kafka.connect.sink.it; import java.io.IOException; +import java.io.InputStream; import java.net.URL; import java.nio.charset.StandardCharsets; import java.nio.file.Files; import java.nio.file.Paths; import java.time.Duration; -import java.util.Arrays; -import java.util.Collections; -import java.util.HashMap; -import java.util.List; -import java.util.Map; -import java.util.Objects; -import java.util.TreeMap; +import java.util.*; import java.util.function.Predicate; import java.util.function.Supplier; import java.util.stream.Collectors; import java.util.stream.Stream; import org.apache.avro.Schema; +import org.apache.avro.SchemaBuilder; import org.apache.avro.generic.GenericData; import org.apache.avro.generic.GenericRecord; import org.apache.commons.io.IOUtils; import org.apache.kafka.clients.producer.KafkaProducer; import org.apache.kafka.clients.producer.ProducerConfig; import org.apache.kafka.clients.producer.ProducerRecord; +import org.apache.kafka.clients.producer.RecordMetadata; +import org.apache.kafka.common.header.Header; +import org.apache.kafka.common.header.internals.RecordHeader; +import org.apache.kafka.common.serialization.ByteArraySerializer; import org.apache.kafka.common.serialization.StringSerializer; import org.jetbrains.annotations.NotNull; import org.json.JSONException; -import org.junit.jupiter.api.*; +import org.junit.jupiter.api.AfterAll; +import org.junit.jupiter.api.Assumptions; +import org.junit.jupiter.api.BeforeAll; +import org.junit.jupiter.api.Test; +import org.junit.jupiter.params.ParameterizedTest; +import org.junit.jupiter.params.provider.CsvSource; import org.skyscreamer.jsonassert.Customization; import org.skyscreamer.jsonassert.JSONAssert; import org.skyscreamer.jsonassert.comparator.CustomComparator; @@ -70,25 +75,25 @@ class KustoSinkIT { private static final Logger log = LoggerFactory.getLogger(KustoSinkIT.class); private static final Network network = Network.newNetwork(); private static final ObjectMapper objectMapper = new ObjectMapper(); - - private static final String confluentVersion = "6.2.5"; + private static final Integer KAFKA_MAX_MSG_SIZE = 3 * 1024 * 1024; + private static final String confluentVersion = "7.5.6"; private static final KafkaContainer kafkaContainer = new KafkaContainer(DockerImageName.parse("confluentinc/cp-kafka:" + confluentVersion)) - .withNetwork(network); - private static final ProxyContainer proxyContainer = new ProxyContainer().withNetwork(network); + .withNetwork(network) + .withEnv("KAFKA_MESSAGE_MAX_BYTES", KAFKA_MAX_MSG_SIZE.toString()) + .withEnv("KAFKA_SOCKET_REQUEST_MAX_BYTES", KAFKA_MAX_MSG_SIZE.toString()); private static final SchemaRegistryContainer schemaRegistryContainer = new SchemaRegistryContainer(confluentVersion).withKafka(kafkaContainer) .withNetwork(network).dependsOn(kafkaContainer); - private static final List testFormats = Arrays.asList("json", "avro", "csv"); // List.of("json", "avro", "csv", "raw"); // Raw for XML - private static ITCoordinates coordinates; + private static final ProxyContainer proxyContainer = new ProxyContainer().withNetwork(network); private static final KustoKafkaConnectContainer connectContainer = new KustoKafkaConnectContainer(confluentVersion) .withNetwork(network) .withKafka(kafkaContainer) .dependsOn(kafkaContainer, proxyContainer, schemaRegistryContainer); - + private static final String keyColumn = "vlong"; + private static final String COMPLEX_AVRO_BYTES_TABLE_TEST = String.format("ComplexAvroBytesTest_%s", UUID.randomUUID()).replace('-', '_'); + private static ITCoordinates coordinates; private static Client engineClient = null; private static Client dmClient = null; - private static final String keyColumn = "vlong"; - @BeforeAll public static void startContainers() throws Exception { coordinates = getConnectorProperties(); @@ -121,7 +126,9 @@ public static void startContainers() throws Exception { private static void createTables() throws Exception { URL kqlResource = KustoSinkIT.class.getClassLoader().getResource("it-table-setup.kql"); assert kqlResource != null; - List kqlsToExecute = Files.readAllLines(Paths.get(kqlResource.toURI())).stream().map(kql -> kql.replace("TBL", coordinates.table)) + List kqlsToExecute = Files.readAllLines(Paths.get(kqlResource.toURI())).stream() + .map(kql -> kql.replace("TBL", coordinates.table)) + .map(kql -> kql.replace("CABT", COMPLEX_AVRO_BYTES_TABLE_TEST)) .collect(Collectors.toList()); kqlsToExecute.forEach(kql -> { try { @@ -130,7 +137,7 @@ private static void createTables() throws Exception { log.error("Failed to execute kql: {}", kql, e); } }); - log.info("Created table {} and associated mappings", coordinates.table); + log.info("Created tables {} , {} and associated mappings", coordinates.table, COMPLEX_AVRO_BYTES_TABLE_TEST); } private static void refreshDm() throws Exception { @@ -151,77 +158,95 @@ private static void refreshDm() throws Exception { @AfterAll public static void stopContainers() throws Exception { + log.info("Finished table clean up. Dropped tables {} and {}", coordinates.table, COMPLEX_AVRO_BYTES_TABLE_TEST); connectContainer.stop(); schemaRegistryContainer.stop(); kafkaContainer.stop(); engineClient.execute(coordinates.database, String.format(".drop table %s", coordinates.table)); - log.warn("Finished table clean up. Dropped table {}", coordinates.table); + engineClient.execute(coordinates.database, String.format(".drop table %s", COMPLEX_AVRO_BYTES_TABLE_TEST)); dmClient.close(); engineClient.close(); } - @Test - public void shouldHandleAllTypesOfEvents() { - Assumptions.assumeTrue(coordinates.isValidConfig(), "Skipping test due to missing configuration"); - String srUrl = String.format("http://%s:%s", schemaRegistryContainer.getContainerId().substring(0, 12), 8081); - testFormats.parallelStream().forEach(dataFormat -> { - String valueFormat = "org.apache.kafka.connect.storage.StringConverter"; - if (dataFormat.equals("avro")) { - valueFormat = AvroConverter.class.getName(); - log.debug("Using value format: {}", valueFormat); - } - String topicTableMapping = dataFormat.equals("csv") - ? String.format("[{'topic': 'e2e.%s.topic','db': '%s', 'table': '%s','format':'%s','mapping':'%s_mapping','streaming':'true'}]", dataFormat, - coordinates.database, - coordinates.table, dataFormat, dataFormat) - : String.format("[{'topic': 'e2e.%s.topic','db': '%s', 'table': '%s','format':'%s','mapping':'%s_mapping'}]", dataFormat, - coordinates.database, - coordinates.table, dataFormat, dataFormat); - log.info("Deploying connector for {} , using SR url {}. Using proxy host {} and port {}", dataFormat, srUrl, - proxyContainer.getContainerId().substring(0, 12), proxyContainer.getExposedPorts().get(0)); - Map connectorProps = new HashMap<>(); - connectorProps.put("connector.class", "com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConnector"); - connectorProps.put("flush.size.bytes", 10000); - connectorProps.put("flush.interval.ms", 1000); - connectorProps.put("tasks.max", 1); - connectorProps.put("topics", String.format("e2e.%s.topic", dataFormat)); - connectorProps.put("kusto.tables.topics.mapping", topicTableMapping); - connectorProps.put("aad.auth.authority", coordinates.authority); - connectorProps.put("aad.auth.accesstoken", coordinates.accessToken); - connectorProps.put("aad.auth.strategy", "AZ_DEV_TOKEN".toLowerCase()); - connectorProps.put("kusto.query.url", coordinates.cluster); - connectorProps.put("kusto.ingestion.url", coordinates.ingestCluster); + private static void deployConnector(@NotNull String dataFormat, String topicTableMapping, + String srUrl, String keyFormat, String valueFormat) { + deployConnector(dataFormat, topicTableMapping, srUrl, keyFormat, valueFormat, Collections.emptyMap()); + } + + private static void deployConnector(@NotNull String dataFormat, String topicTableMapping, + String srUrl, String keyFormat, String valueFormat, + Map overrideProps) { + Map connectorProps = new HashMap<>(); + connectorProps.put("connector.class", "com.microsoft.azure.kusto.kafka.connect.sink.KustoSinkConnector"); + connectorProps.put("flush.size.bytes", 10000); + connectorProps.put("flush.interval.ms", 1000); + connectorProps.put("tasks.max", 1); + connectorProps.put("topics", String.format("e2e.%s.topic", dataFormat)); + connectorProps.put("kusto.tables.topics.mapping", topicTableMapping); + connectorProps.put("aad.auth.authority", coordinates.authority); + connectorProps.put("aad.auth.accesstoken", coordinates.accessToken); + connectorProps.put("aad.auth.strategy", "AZ_DEV_TOKEN".toLowerCase()); + connectorProps.put("kusto.query.url", coordinates.cluster); + connectorProps.put("kusto.ingestion.url", coordinates.ingestCluster); + if (!dataFormat.startsWith("bytes")) { connectorProps.put("schema.registry.url", srUrl); connectorProps.put("value.converter.schema.registry.url", srUrl); - connectorProps.put("key.converter", "org.apache.kafka.connect.storage.StringConverter"); - connectorProps.put("value.converter", valueFormat); - connectorProps.put("proxy.host", proxyContainer.getContainerId().substring(0, 12)); - connectorProps.put("proxy.port", proxyContainer.getExposedPorts().get(0)); - connectContainer.registerConnector(String.format("adx-connector-%s", dataFormat), connectorProps); - log.info("Deployed connector for {}", dataFormat); - log.debug(connectContainer.getLogs()); - }); - testFormats.parallelStream().forEach(dataFormat -> { - connectContainer.waitUntilConnectorTaskStateChanges(String.format("adx-connector-%s", dataFormat), 0, "RUNNING"); - log.info("Connector state for {} : {}. ", dataFormat, - connectContainer.getConnectorTaskState(String.format("adx-connector-%s", dataFormat), 0)); - try { - produceKafkaMessages(dataFormat); - Thread.sleep(10000); - } catch (IOException | InterruptedException e) { - throw new RuntimeException(e); - } - }); + } + connectorProps.put("key.converter", keyFormat); + connectorProps.put("value.converter", valueFormat); + connectorProps.put("proxy.host", proxyContainer.getContainerId().substring(0, 12)); + connectorProps.put("proxy.port", proxyContainer.getExposedPorts().get(0)); + connectorProps.putAll(overrideProps); + connectContainer.registerConnector(String.format("adx-connector-%s", dataFormat), connectorProps); + log.debug("Deployed connector for {}", dataFormat); + log.debug(connectContainer.getLogs()); + connectContainer.waitUntilConnectorTaskStateChanges(String.format("adx-connector-%s", dataFormat), 0, "RUNNING"); + log.info("Connector state for {} : {}. ", dataFormat, + connectContainer.getConnectorTaskState(String.format("adx-connector-%s", dataFormat), 0)); + } + + @ParameterizedTest + @CsvSource({"json", "avro", "csv", "bytes-json"}) + public void shouldHandleAllTypesOfEvents(@NotNull String dataFormat) { + log.info("Running test for data format {}", dataFormat); + Assumptions.assumeTrue(coordinates.isValidConfig(), "Skipping test due to missing configuration"); + String srUrl = String.format("http://%s:%s", schemaRegistryContainer.getContainerId().substring(0, 12), 8081); + String valueFormat = "org.apache.kafka.connect.storage.StringConverter"; + String keyFormat = "org.apache.kafka.connect.storage.StringConverter"; + if (dataFormat.equals("avro")) { + valueFormat = AvroConverter.class.getName(); + log.debug("Using value format: {}", valueFormat); + } + String topicTableMapping = dataFormat.equals("csv") + ? String.format("[{'topic': 'e2e.%s.topic','db': '%s', 'table': '%s','format':'%s','mapping':'csv_mapping','streaming':'true'}]", + dataFormat, coordinates.database, coordinates.table, dataFormat) + : String.format("[{'topic': 'e2e.%s.topic','db': '%s', 'table': '%s','format':'%s','mapping':'data_mapping'}]", dataFormat, + coordinates.database, + coordinates.table, dataFormat); + if (dataFormat.startsWith("bytes")) { + valueFormat = "org.apache.kafka.connect.converters.ByteArrayConverter"; + // JSON is written as JSON + topicTableMapping = String.format("[{'topic': 'e2e.%s.topic','db': '%s', 'table': '%s','format':'%s'," + + "'mapping':'data_mapping'}]", dataFormat, + coordinates.database, + coordinates.table, dataFormat.split("-")[1]); + } + log.info("Deploying connector for {} , using SR url {}. Using proxy host {} and port {}", dataFormat, srUrl, + proxyContainer.getContainerId().substring(0, 12), proxyContainer.getExposedPorts().get(0)); + deployConnector(dataFormat, topicTableMapping, srUrl, keyFormat, valueFormat); + try { + produceKafkaMessages(dataFormat); + Thread.sleep(10_000); + } catch (IOException | InterruptedException e) { + throw new RuntimeException(e); + } } private void produceKafkaMessages(@NotNull String dataFormat) throws IOException { - log.debug("Producing messages"); + log.info("Producing messages"); int maxRecords = 10; Map producerProperties = new HashMap<>(); producerProperties.put(ProducerConfig.BOOTSTRAP_SERVERS_CONFIG, kafkaContainer.getBootstrapServers()); - producerProperties.put(AbstractKafkaSchemaSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG, - String.format("http://%s:%s", schemaRegistryContainer.getHost(), schemaRegistryContainer.getFirstMappedPort())); - producerProperties.put(AbstractKafkaSchemaSerDeConfig.AUTO_REGISTER_SCHEMAS, true); // avro Generator.Builder builder = new Generator.Builder().schemaString(IOUtils.toString( Objects.requireNonNull(this.getClass().getClassLoader().getResourceAsStream("it-avro.avsc")), @@ -233,14 +258,20 @@ private void produceKafkaMessages(@NotNull String dataFormat) throws IOException case "avro": producerProperties.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, StringSerializer.class); producerProperties.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, KafkaAvroSerializer.class); + producerProperties.put(AbstractKafkaSchemaSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG, + String.format("http://%s:%s", schemaRegistryContainer.getHost(), schemaRegistryContainer.getFirstMappedPort())); + producerProperties.put(AbstractKafkaSchemaSerDeConfig.AUTO_REGISTER_SCHEMAS, true); // GenericRecords to bytes using avro try (KafkaProducer producer = new KafkaProducer<>(producerProperties)) { for (int i = 0; i < maxRecords; i++) { GenericData.Record record = (GenericData.Record) randomDataBuilder.generate(); - ProducerRecord producerRecord = new ProducerRecord<>("e2e.avro.topic", "Key-" + i, record); + record.put("vtype", dataFormat); + List
headers = new ArrayList<>(); + headers.add(new RecordHeader("Iteration", (dataFormat + "-Header" + i).getBytes())); + ProducerRecord producerRecord = new ProducerRecord<>("e2e.avro.topic", 0, "Key-" + i, record, headers); Map jsonRecordMap = record.getSchema().getFields().stream() .collect(Collectors.toMap(Schema.Field::name, field -> record.get(field.name()))); - jsonRecordMap.put("type", dataFormat); + jsonRecordMap.put("vtype", "avro"); expectedRecordsProduced.put(Long.valueOf(jsonRecordMap.get(keyColumn).toString()), objectMapper.writeValueAsString(jsonRecordMap)); producer.send(producerRecord); @@ -250,15 +281,21 @@ private void produceKafkaMessages(@NotNull String dataFormat) throws IOException case "json": producerProperties.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, StringSerializer.class); producerProperties.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, StringSerializer.class); + producerProperties.put(AbstractKafkaSchemaSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG, + String.format("http://%s:%s", schemaRegistryContainer.getHost(), schemaRegistryContainer.getFirstMappedPort())); + producerProperties.put(AbstractKafkaSchemaSerDeConfig.AUTO_REGISTER_SCHEMAS, true); // GenericRecords to json using avro try (KafkaProducer producer = new KafkaProducer<>(producerProperties)) { for (int i = 0; i < maxRecords; i++) { GenericRecord record = (GenericRecord) randomDataBuilder.generate(); + record.put("vtype", "json"); Map jsonRecordMap = record.getSchema().getFields().stream() .collect(Collectors.toMap(Schema.Field::name, field -> record.get(field.name()))); - ProducerRecord producerRecord = new ProducerRecord<>("e2e.json.topic", "Key-" + i, - objectMapper.writeValueAsString(jsonRecordMap)); - jsonRecordMap.put("type", dataFormat); + List
headers = new ArrayList<>(); + headers.add(new RecordHeader("Iteration", (dataFormat + "-Header" + i).getBytes())); + ProducerRecord producerRecord = new ProducerRecord<>("e2e.json.topic", + 0, "Key-" + i, objectMapper.writeValueAsString(jsonRecordMap), headers); + jsonRecordMap.put("vtype", dataFormat); expectedRecordsProduced.put(Long.valueOf(jsonRecordMap.get(keyColumn).toString()), objectMapper.writeValueAsString(jsonRecordMap)); log.debug("JSON Record produced: {}", objectMapper.writeValueAsString(jsonRecordMap)); @@ -269,36 +306,75 @@ private void produceKafkaMessages(@NotNull String dataFormat) throws IOException case "csv": producerProperties.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, StringSerializer.class); producerProperties.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, StringSerializer.class); + producerProperties.put(AbstractKafkaSchemaSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG, + String.format("http://%s:%s", schemaRegistryContainer.getHost(), schemaRegistryContainer.getFirstMappedPort())); + producerProperties.put(AbstractKafkaSchemaSerDeConfig.AUTO_REGISTER_SCHEMAS, true); // GenericRecords to json using avro try (KafkaProducer producer = new KafkaProducer<>(producerProperties)) { for (int i = 0; i < maxRecords; i++) { GenericRecord record = (GenericRecord) randomDataBuilder.generate(); + record.put("vtype", "csv"); Map jsonRecordMap = new TreeMap<>(record.getSchema().getFields().stream().parallel() .collect(Collectors.toMap(Schema.Field::name, field -> record.get(field.name())))); String objectsCommaSeparated = jsonRecordMap.values().stream().map(Object::toString).collect(Collectors.joining(",")); log.debug("CSV Record produced: {}", objectsCommaSeparated); - ProducerRecord producerRecord = new ProducerRecord<>("e2e.csv.topic", "Key-" + i, - objectsCommaSeparated); - jsonRecordMap.put("type", dataFormat); + List
headers = new ArrayList<>(); + headers.add(new RecordHeader("Iteration", (dataFormat + "-Header" + i).getBytes())); + ProducerRecord producerRecord = new ProducerRecord<>("e2e.csv.topic", 0, "Key-" + i, + objectsCommaSeparated, headers); + jsonRecordMap.put("vtype", dataFormat); expectedRecordsProduced.put(Long.valueOf(jsonRecordMap.get(keyColumn).toString()), objectMapper.writeValueAsString(jsonRecordMap)); producer.send(producerRecord); } } break; + case "bytes-json": + producerProperties.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, StringSerializer.class); + producerProperties.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, ByteArraySerializer.class); + // GenericRecords to json using avro + try (KafkaProducer producer = new KafkaProducer<>(producerProperties)) { + for (int i = 0; i < maxRecords; i++) { + GenericRecord record = (GenericRecord) randomDataBuilder.generate(); + record.put("vtype", "bytes-json"); + // Serialization test for Avro as bytes , or JSON as bytes (Schemaless tests) + byte[] dataToSend = record.toString().getBytes(StandardCharsets.UTF_8); + Map jsonRecordMap = record.getSchema().getFields().stream() + .collect(Collectors.toMap(Schema.Field::name, field -> record.get(field.name()))); + ProducerRecord producerRecord = new ProducerRecord<>( + String.format("e2e.%s.topic", dataFormat), + String.format("Key-%s", i), + dataToSend); + jsonRecordMap.put("vtype", dataFormat); + expectedRecordsProduced.put(Long.valueOf(jsonRecordMap.get(keyColumn).toString()), + objectMapper.writeValueAsString(jsonRecordMap)); + log.info("Bytes topic {} written to", String.format("e2e.%s.topic", dataFormat)); + try { + RecordMetadata rmd = producer.send(producerRecord).get(); + log.info("Record sent to topic {} with offset {} of size {}", + String.format("e2e.%s.topic", dataFormat), rmd.offset(), dataToSend.length); + } catch (Exception e) { + log.error("Failed to send record to topic {}", String.format("e2e.%s.topic", dataFormat), e); + } + } + } + break; } log.info("Produced messages for format {}", dataFormat); - Map actualRecordsIngested = getRecordsIngested(dataFormat, maxRecords); + String query = String.format("%s | where vtype == '%s' | project %s,vresult = pack_all()", + coordinates.table, dataFormat, keyColumn); + Map actualRecordsIngested = getRecordsIngested(query, maxRecords); actualRecordsIngested.keySet().parallelStream().forEach(key -> { + long keyLong = Long.parseLong(key.toString()); log.debug("Record queried in assertion : {}", actualRecordsIngested.get(key)); try { - JSONAssert.assertEquals(expectedRecordsProduced.get(key), actualRecordsIngested.get(key), + JSONAssert.assertEquals(expectedRecordsProduced.get(keyLong), actualRecordsIngested.get(key), new CustomComparator(LENIENT, // there are sometimes round off errors in the double values but they are close enough to 8 precision new Customization("vdec", (vdec1, - vdec2) -> Math.abs(Double.parseDouble(vdec1.toString()) - Double.parseDouble(vdec2.toString())) < 0.000000001), + vdec2) -> Math.abs(Double.parseDouble(vdec1.toString()) - Double.parseDouble(vdec2.toString())) < 0.000000001), new Customization("vreal", (vreal1, - vreal2) -> Math.abs(Double.parseDouble(vreal1.toString()) - Double.parseDouble(vreal2.toString())) < 0.0001))); + vreal2) -> Math.abs(Double.parseDouble(vreal1.toString()) - Double.parseDouble(vreal2.toString())) < 0.0001))); } catch (JSONException e) { fail(e); } @@ -306,11 +382,84 @@ private void produceKafkaMessages(@NotNull String dataFormat) throws IOException assertEquals(maxRecords, actualRecordsIngested.size()); } - private @NotNull Map getRecordsIngested(String dataFormat, int maxRecords) { - String query = String.format("%s | where type == '%s' | project %s,vresult = pack_all()", coordinates.table, dataFormat, keyColumn); + @Test + public void shouldHandleComplexAvroMessage() throws IOException { + String dataFormat = "bytes-avro"; + int maxRecords = 8; + String srUrl = String.format("http://%s:%s", schemaRegistryContainer.getContainerId().substring(0, 12), 8081); + String producerSrUrl = String.format("http://localhost:%s", schemaRegistryContainer.getMappedPort(8081)); + Map producerProperties = new HashMap<>(); + producerProperties.put(ProducerConfig.BOOTSTRAP_SERVERS_CONFIG, kafkaContainer.getBootstrapServers()); + producerProperties.put(ProducerConfig.KEY_SERIALIZER_CLASS_CONFIG, "io.confluent.kafka.serializers.KafkaAvroSerializer"); + producerProperties.put(ProducerConfig.VALUE_SERIALIZER_CLASS_CONFIG, ByteArraySerializer.class); + producerProperties.put(AbstractKafkaSchemaSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG, producerSrUrl); + producerProperties.put("key.schema.registry.url", producerSrUrl); + producerProperties.put(ProducerConfig.MAX_REQUEST_SIZE_CONFIG, KAFKA_MAX_MSG_SIZE); + producerProperties.put(ProducerConfig.BATCH_SIZE_CONFIG, KAFKA_MAX_MSG_SIZE * 5); + producerProperties.put("message.max.bytes", KAFKA_MAX_MSG_SIZE); + String topicName = String.format("e2e.%s.topic", dataFormat); + String topicTableMapping = String.format("[{'topic': '%s','db': '%s', " + + "'table': '%s','format':'%s','mapping':'%s_mapping'}]", topicName, + coordinates.database, + COMPLEX_AVRO_BYTES_TABLE_TEST, dataFormat.split("-")[1], COMPLEX_AVRO_BYTES_TABLE_TEST); + deployConnector(dataFormat, topicTableMapping, srUrl, + AvroConverter.class.getName(), + "org.apache.kafka.connect.converters.ByteArrayConverter", + Collections.singletonMap("key.converter.schema.registry.url", srUrl)); + Schema keySchema = SchemaBuilder + .record("Key").namespace("com.ms.kafka.connect.sink.avro") + .fields() + .name("IterationKey").type().stringType().noDefault() + .name("Timestamp").type().nullable().longType().noDefault() + .endRecord(); + long keyStart = 100000L; + + InputStream expectedResultsStream = Objects + .requireNonNull(this.getClass().getClassLoader().getResourceAsStream("avro-complex-data/expected-results.txt")); + String expectedResults = IOUtils.toString(expectedResultsStream, StandardCharsets.UTF_8); + Map expectedResultMap = Arrays.stream(expectedResults.split("\n")) + .map(line -> line.split("~")) + .collect(Collectors.toMap(arr -> arr[0], arr -> arr[1])); + try (KafkaProducer producer = new KafkaProducer<>(producerProperties)) { + for (int i = 1; i <= maxRecords; i++) { + // complex-avro-1.avro + long keyTick = keyStart + i; + GenericData.Record keyRecord = new GenericData.Record(keySchema); + keyRecord.put("IterationKey", String.valueOf(i)); + keyRecord.put("Timestamp", keyTick); + InputStream avroData = Objects + .requireNonNull(this.getClass().getClassLoader().getResourceAsStream(String.format("avro-complex-data/complex-avro-%d.avro", i))); + byte[] testData = IOUtils.toByteArray(avroData); + ProducerRecord producerRecord = new ProducerRecord<>(topicName, keyRecord, testData); + producerRecord.headers().add("vtype", dataFormat.getBytes()); + producerRecord.headers().add("iteration", String.valueOf(i).getBytes()); + RecordMetadata rmd = producer.send(producerRecord).get(); + log.info("Avro bytes sent to topic {} with offset {} of size {}", topicName, rmd.offset(), testData.length); + } + Thread.sleep(30_000); + } catch (Exception e) { + log.error("Failed to send record to topic {}", topicName, e); + fail("Failed sending message to Kafka for testing Avro-Bytes scenario."); + } + + String countLongQuery = String.format("%s | summarize c = count() by event_id | project %s=event_id, " + + "vresult = bag_pack('event_id',event_id,'count',c)", COMPLEX_AVRO_BYTES_TABLE_TEST, keyColumn); + + Map actualRecordsIngested = getRecordsIngested(countLongQuery, maxRecords); + assertEquals(expectedResultMap, actualRecordsIngested); + } + + /** + * Polls the Kusto table for the records ingested. The query is executed every 30 seconds and the results are + * + * @param query The query to execute + * @param maxRecords The maximum number of records to poll for + * @return A map of the records ingested + */ + private @NotNull Map getRecordsIngested(String query, int maxRecords) { Predicate predicate = (results) -> { if (results != null) { - log.debug("Retrieved records count {}", ((Map) results).size()); + log.info("Retrieved records count {}", ((Map) results).size()); } return results == null || ((Map) results).isEmpty() || ((Map) results).size() < maxRecords; }; @@ -322,15 +471,16 @@ private void produceKafkaMessages(@NotNull String dataFormat) throws IOException .build(); RetryRegistry registry = RetryRegistry.of(config); Retry retry = registry.retry("ingestRecordService", config); - Supplier> recordSearchSupplier = () -> { + Supplier> recordSearchSupplier = () -> { try { log.debug("Executing query {} ", query); KustoResultSetTable resultSet = engineClient.execute(coordinates.database, query).getPrimaryResults(); - Map actualResults = new HashMap<>(); + Map actualResults = new HashMap<>(); while (resultSet.next()) { - Long key = (long) resultSet.getInt(keyColumn); + Object keyObject = resultSet.getObject(keyColumn); + Object key = keyObject instanceof Number ? Long.parseLong(keyObject.toString()) : keyObject.toString(); String vResult = resultSet.getString("vresult"); - log.debug("Record queried: {}", vResult); + log.debug("Record queried from DB: {}", vResult); actualResults.put(key, vResult); } return actualResults; diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/KustoKafkaConnectContainer.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/KustoKafkaConnectContainer.java index d151c71b..ddb3c6de 100644 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/KustoKafkaConnectContainer.java +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/KustoKafkaConnectContainer.java @@ -16,6 +16,7 @@ import org.apache.http.impl.client.HttpClients; import org.apache.http.util.EntityUtils; import org.awaitility.Awaitility; +import org.jetbrains.annotations.NotNull; import org.slf4j.Logger; import org.slf4j.LoggerFactory; import org.testcontainers.containers.GenericContainer; @@ -43,7 +44,7 @@ public KustoKafkaConnectContainer(final String version) { withExposedPorts(KAFKA_CONNECT_PORT); } - public KustoKafkaConnectContainer withKafka(final KafkaContainer kafkaContainer) { + public KustoKafkaConnectContainer withKafka(final @NotNull KafkaContainer kafkaContainer) { return withKafka(kafkaContainer.getNetwork(), kafkaContainer.getNetworkAliases().get(0) + ":9092"); } diff --git a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/SchemaRegistryContainer.java b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/SchemaRegistryContainer.java index eae57d65..40acf7b3 100644 --- a/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/SchemaRegistryContainer.java +++ b/src/test/java/com/microsoft/azure/kusto/kafka/connect/sink/it/containers/SchemaRegistryContainer.java @@ -1,5 +1,6 @@ package com.microsoft.azure.kusto.kafka.connect.sink.it.containers; +import org.jetbrains.annotations.NotNull; import org.testcontainers.containers.GenericContainer; import org.testcontainers.containers.KafkaContainer; import org.testcontainers.containers.Network; @@ -15,12 +16,13 @@ public SchemaRegistryContainer(String version) { withExposedPorts(SCHEMA_REGISTRY_PORT); } - public SchemaRegistryContainer withKafka(KafkaContainer kafka) { + public SchemaRegistryContainer withKafka(@NotNull KafkaContainer kafka) { return withKafka(kafka.getNetwork(), kafka.getNetworkAliases().get(0) + ":9092"); } public SchemaRegistryContainer withKafka(Network network, String bootstrapServers) { - withNetwork(network).withEnv("SCHEMA_REGISTRY_HOST_NAME", "schema-registry").withEnv("SCHEMA_REGISTRY_LISTENERS", "http://0.0.0.0:8081") + withNetwork(network).withEnv("SCHEMA_REGISTRY_HOST_NAME", "schema-registry") + .withEnv("SCHEMA_REGISTRY_LISTENERS", "http://0.0.0.0:8081") .withEnv("SCHEMA_REGISTRY_KAFKASTORE_BOOTSTRAP_SERVERS", "PLAINTEXT://" + bootstrapServers); return self(); } diff --git a/src/test/resources/avro-complex-data/complex-avro-1.avro b/src/test/resources/avro-complex-data/complex-avro-1.avro new file mode 100644 index 00000000..e07d3859 --- /dev/null +++ b/src/test/resources/avro-complex-data/complex-avro-1.avro @@ -0,0 +1,7242 @@ +Objavro.schema{"type":"record","name":"MixerOfferEvent","namespace":"es.eci.firefly.avro.mixer.event","fields":[{"name":"business_event_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"business_object","type":{"type":"record","name":"MixerOffer","namespace":"es.eci.firefly.avro.mixer.model","fields":[{"name":"applied_taxes","type":["null",{"type":"array","items":{"type":"record","name":"AppliedTaxes","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer","fields":[{"name":"type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.AppliedTaxes"}}],"default":null},{"name":"availability_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"availability_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":{"type":"record","name":"Product","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer","fields":[{"name":"additional_product_descriptions","type":["null",{"type":"array","items":{"type":"record","name":"ProductAdditionalDescription","fields":[{"name":"end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductAdditionalDescriptionType","io.confluent.connect.avro.Enum.VARIETY":"VARIETY","io.confluent.connect.avro.Enum.VARIETY_STORE":"VARIETY_STORE","io.confluent.connect.avro.Enum.OTHER":"OTHER","io.confluent.connect.avro.Enum.ARTICLE":"ARTICLE","io.confluent.connect.avro.Enum.TEMPORAL":"TEMPORAL","io.confluent.connect.avro.Enum.TICKET":"TICKET"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductAdditionalDescriptionType"}},{"name":"value","type":["null",{"type":"array","items":{"type":"record","name":"I18nText","fields":[{"name":"locale","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductAdditionalDescription"}}],"default":null},{"name":"badges","type":["null",{"type":"array","items":{"type":"record","name":"Badge","fields":[{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null",{"type":"record","name":"Glossary","fields":[{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"media_objects","type":["null",{"type":"array","items":{"type":"record","name":"MediaObject","fields":[{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"media_category_order","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"media_category_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"media_type","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.MediaObjectType","io.confluent.connect.avro.Enum.AUDIO":"AUDIO","io.confluent.connect.avro.Enum.IMAGE":"IMAGE","io.confluent.connect.avro.Enum.VIDEO":"VIDEO","io.confluent.connect.avro.Enum.DOCUMENT":"DOCUMENT","io.confluent.connect.avro.Enum.LINK":"LINK"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.MediaObjectType"}},{"name":"size","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"tags","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"url","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.MediaObject"}}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"term","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Glossary"}],"default":null},{"name":"icon","type":["null","MediaObject"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Badge"}}],"default":null},{"name":"bar_code_variants","type":["null",{"type":"array","items":{"type":"record","name":"BarCodeVariant","fields":[{"name":"date_created_procurement","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gtin","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_main","type":["null","boolean"],"default":null},{"name":"promotional_end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"promotional_start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BarCodeVariant"}}],"default":null},{"name":"basic_color","type":["null",{"type":"record","name":"Color","fields":[{"name":"color_code","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"color_description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Color"}],"default":null},{"name":"brand","type":["null",{"type":"record","name":"Brand","fields":[{"name":"external_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_eci_brand","type":["null","boolean"],"default":null},{"name":"media_objects","type":["null",{"type":"array","items":"MediaObject"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"url_links","type":["null",{"type":"array","items":{"type":"record","name":"BrandSiteLink","fields":[{"name":"site","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"url","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BrandSiteLink"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Brand"}],"default":null},{"name":"calculated_badges","type":["null",{"type":"array","items":{"type":"record","name":"CalculatedBadge","fields":[{"name":"center_value","type":["null",{"type":"array","items":{"type":"record","name":"PackingUnitsBadge","fields":[{"name":"center","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PackingUnitsBadge"}}],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.CalculatedBadge"}}],"default":null},{"name":"canonical_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"categories","type":["null",{"type":"array","items":{"type":"record","name":"Category","fields":[{"name":"classifications","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"has_more_direct_children","type":["null","boolean"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"metadata","type":["null",{"type":"record","name":"Metadata","fields":[{"name":"is_publish","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Metadata"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"order_in_parent","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"parent_category","type":["null","Category"],"default":null},{"name":"type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.CategoryType","io.confluent.connect.avro.Enum.CD":"CD","io.confluent.connect.avro.Enum.CG":"CG","io.confluent.connect.avro.Enum.I":"I","io.confluent.connect.avro.Enum.L":"L","io.confluent.connect.avro.Enum.LC":"LC","io.confluent.connect.avro.Enum.LE":"LE","io.confluent.connect.avro.Enum.LM":"LM","io.confluent.connect.avro.Enum.LP":"LP","io.confluent.connect.avro.Enum.LS":"LS","io.confluent.connect.avro.Enum.MM":"MM","io.confluent.connect.avro.Enum.MP":"MP","io.confluent.connect.avro.Enum.N":"N","io.confluent.connect.avro.Enum.PP":"PP","io.confluent.connect.avro.Enum.PT":"PT","io.confluent.connect.avro.Enum.R":"R"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.CategoryType"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Category"}}],"default":null},{"name":"center_packing_units","type":["null",{"type":"array","items":{"type":"record","name":"CenterPackingUnits","fields":[{"name":"center_id","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"units_by_center","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.CenterPackingUnits"}}],"default":null},{"name":"color","type":["null","Color"],"default":null},{"name":"cross_selling","type":["null",{"type":"array","items":"BarCodeVariant"}],"default":null},{"name":"cross_selling_product_ids","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"customised_request","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_created_catalog","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"depth","type":["null",{"type":"record","name":"QuantitativeValue","fields":[{"name":"unit_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"unit_text","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"value","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.QuantitativeValue"}],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"description_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"digital_store","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"edition_type","type":["null",{"type":"record","name":"LookupTable","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.LookupTable"}],"default":null},{"name":"edition_types","type":["null",{"type":"array","items":"LookupTable"}],"default":null},{"name":"energy_rating","type":["null",{"type":"record","name":"EnergyRating","fields":[{"name":"classification","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.EnergyRating"}],"default":null},{"name":"environment_signal","type":["null",{"type":"record","name":"EnvironmentSignal","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.EnvironmentSignal"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gift_card_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gross_volume","type":["null","QuantitativeValue"],"default":null},{"name":"gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"h1_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"has_complete_documentation","type":["null","boolean"],"default":null},{"name":"has_own_pum","type":["null","boolean"],"default":null},{"name":"height","type":["null","QuantitativeValue"],"default":null},{"name":"highlighted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"image_color","type":["null",{"type":"record","name":"ImageColor","fields":[{"name":"mode","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":{"type":"array","items":"I18nText"}},{"name":"ratio","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"url","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ImageColor"}],"default":null},{"name":"internal_gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"is_best_sellers_excluded","type":["null","boolean"],"default":null},{"name":"is_comparable","type":["null","boolean"],"default":null},{"name":"is_digital","type":["null","boolean"],"default":null},{"name":"is_eci_express","type":["null","boolean"],"default":null},{"name":"is_eci_express_exclusive","type":["null","boolean"],"default":null},{"name":"is_followed","type":["null","boolean"],"default":null},{"name":"is_indexed","type":["null","boolean"],"default":null},{"name":"is_infinite_stock","type":["null","boolean"],"default":null},{"name":"is_luxury","type":["null","boolean"],"default":null},{"name":"is_soldable_without_image","type":["null","boolean"],"default":null},{"name":"is_variant_of","type":["null","Product"],"default":null},{"name":"is_weight_scale","type":["null","boolean"],"default":null},{"name":"keyword_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"legislation","type":["null",{"type":"array","items":{"type":"record","name":"Legislation","fields":[{"name":"applicable_regulation","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"product_type","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"security_information","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Legislation"}}],"default":null},{"name":"license","type":["null","LookupTable"],"default":null},{"name":"main_category","type":["null","Category"],"default":null},{"name":"manufacturer","type":["null",{"type":"record","name":"Organization","fields":[{"name":"description","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"postal_address","type":["null",{"type":"record","name":"PostalAddress","fields":[{"name":"street_address","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PostalAddress"}],"default":null},{"name":"telephone","type":["null",{"type":"record","name":"Telephone","fields":[{"name":"number","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Telephone"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Organization"}],"default":null},{"name":"max_weight","type":["null","QuantitativeValue"],"default":null},{"name":"min_weight","type":["null","QuantitativeValue"],"default":null},{"name":"model_detail","type":["null",{"type":"record","name":"ModelDetail","fields":[{"name":"model_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"web_model_description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"web_model_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ModelDetail"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"offers","type":["null",{"type":"array","items":{"type":"record","name":"Offer","fields":[{"name":"applied_taxes","type":["null",{"type":"array","items":"AppliedTaxes"}],"default":null},{"name":"availability_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"availability_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":"Product"}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_deleted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_recoded","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_point","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_type_badges","type":["null",{"type":"record","name":"DeliveryTypes","fields":[{"name":"is_eci_express","type":["null","boolean"],"default":null},{"name":"is_eci_pickup","type":["null","boolean"],"default":null},{"name":"is_home_delivery","type":["null","boolean"],"default":null},{"name":"is_internet_exclusive","type":["null","boolean"],"default":null},{"name":"is_sts_pickup","type":["null","boolean"],"default":null},{"name":"sts_companies","type":["null",{"type":"array","items":"Organization"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.DeliveryTypes"}],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"financing_data","type":["null",{"type":"record","name":"FinancingData","fields":[{"name":"end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"grace_period","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"has_calculator","type":["null","boolean"],"default":null},{"name":"is_no_interest","type":["null","boolean"],"default":null},{"name":"monthly_payments","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"number_payments","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"total_amount","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type","type":["null","LookupTable"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.FinancingData"}],"default":null},{"name":"good_types","type":["null",{"type":"array","items":{"type":"record","name":"GoodType","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.GoodType"}}],"default":null},{"name":"has_european_conformity_certification","type":["null","boolean"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_non_technological","type":["null","boolean"],"default":null},{"name":"is_publish","type":["null","boolean"],"default":null},{"name":"is_return_allowed","type":["null","boolean"],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_searchable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null",{"type":"record","name":"ProductVariant","fields":[{"name":"additional_product_descriptions","type":["null",{"type":"array","items":"ProductAdditionalDescription"}],"default":null},{"name":"badges","type":["null",{"type":"array","items":"Badge"}],"default":null},{"name":"bar_code_variants","type":["null",{"type":"array","items":"BarCodeVariant"}],"default":null},{"name":"basic_color","type":["null","Color"],"default":null},{"name":"calculated_badges","type":["null",{"type":"array","items":"CalculatedBadge"}],"default":null},{"name":"color","type":["null","Color"],"default":null},{"name":"customised_request","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_created_catalog","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"depth","type":["null","QuantitativeValue"],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"digital_store","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"edition_type","type":["null","LookupTable"],"default":null},{"name":"edition_types","type":["null",{"type":"array","items":"LookupTable"}],"default":null},{"name":"energy_rating","type":["null","EnergyRating"],"default":null},{"name":"environment_signal","type":["null","EnvironmentSignal"],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gross_volume","type":["null","QuantitativeValue"],"default":null},{"name":"gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"has_complete_documentation","type":["null","boolean"],"default":null},{"name":"has_own_pum","type":["null","boolean"],"default":null},{"name":"height","type":["null","QuantitativeValue"],"default":null},{"name":"highlighted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"image_color","type":["null","ImageColor"],"default":null},{"name":"internal_gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"is_best_sellers_excluded","type":["null","boolean"],"default":null},{"name":"is_comparable","type":["null","boolean"],"default":null},{"name":"is_digital","type":["null","boolean"],"default":null},{"name":"is_eci_express","type":["null","boolean"],"default":null},{"name":"is_eci_express_exclusive","type":["null","boolean"],"default":null},{"name":"is_infinite_stock","type":["null","boolean"],"default":null},{"name":"is_luxury","type":["null","boolean"],"default":null},{"name":"is_soldable_without_image","type":["null","boolean"],"default":null},{"name":"is_variant_of","type":["null","Product"],"default":null},{"name":"is_weight_scale","type":["null","boolean"],"default":null},{"name":"license","type":["null","LookupTable"],"default":null},{"name":"manufacturer","type":["null","Organization"],"default":null},{"name":"max_weight","type":["null","QuantitativeValue"],"default":null},{"name":"min_weight","type":["null","QuantitativeValue"],"default":null},{"name":"model_detail","type":["null","ModelDetail"],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"offers","type":["null",{"type":"array","items":"Offer"}],"default":null},{"name":"pantone","type":["null","LookupTable"],"default":null},{"name":"piece_weight","type":["null","QuantitativeValue"],"default":null},{"name":"presentation_details","type":["null",{"type":"record","name":"PresentationDetails","fields":[{"name":"format","type":["null",{"type":"record","name":"Format","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Format"}],"default":null},{"name":"freshness","type":["null",{"type":"record","name":"Freshness","fields":[{"name":"freshness_days","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"is_alive","type":["null","boolean"],"default":null},{"name":"is_consum_day","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Freshness"}],"default":null},{"name":"is_panification_product","type":["null","boolean"],"default":null},{"name":"package_unit","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"presentation","type":["null",{"type":"record","name":"Presentation","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Presentation"}],"default":null},{"name":"quantity","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PresentationDetails"}],"default":null},{"name":"previous_gtins","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"priority_number","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"product_description","type":["null",{"type":"array","items":{"type":"record","name":"I18nProductDescription","fields":[{"name":"locale","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"array","items":{"type":"record","name":"ProductDescription","fields":[{"name":"name","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"value","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductDescription"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nProductDescription"}}],"default":null},{"name":"purchase_management_stock","type":["null",{"type":"record","name":"PurchaseManagementStock","fields":[{"name":"classifications","type":["null",{"type":"array","items":{"type":"record","name":"Classification","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Classification"}}],"default":null},{"name":"management_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PurchaseManagementStock"}],"default":null},{"name":"range","type":["null",{"type":"record","name":"Range","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer.features","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.features.Range"}],"default":null},{"name":"related_services","type":["null",{"type":"array","items":{"type":"record","name":"SignalService","fields":[{"name":"mode","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"name","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SignalService"}}],"default":null},{"name":"sale_type","type":["null","LookupTable"],"default":null},{"name":"service_agreement_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"sizes","type":["null",{"type":"array","items":{"type":"record","name":"SizeInfo","fields":[{"name":"main_size","type":["null",{"type":"record","name":"Size","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"size_type","type":["null",{"type":"record","name":"SizeType","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SizeType"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Size"}],"default":null},{"name":"manufacturer_size","type":["null","Size"],"default":null},{"name":"name","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SizeInfo"}}],"default":null},{"name":"special_handling_type","type":["null",{"type":"record","name":"SpecialHandlingType","fields":[{"name":"is_alcohol","type":["null","boolean"],"default":null},{"name":"is_preparation_required","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SpecialHandlingType"}],"default":null},{"name":"special_merchandise_indicator","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"specific_attribute_groups","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"specific_attributes","type":["null",{"type":"array","items":{"type":"record","name":"SpecificAttributes","fields":[{"name":"attributes","type":["null",{"type":"array","items":{"type":"record","name":"Attribute","fields":[{"name":"cardinality","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.AttributeCardinality","io.confluent.connect.avro.Enum.ONE":"ONE","io.confluent.connect.avro.Enum.MANY":"MANY"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.AttributeCardinality"}},{"name":"is_i18n","type":"boolean"},{"name":"name","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"values","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Attribute"}}],"default":null},{"name":"group_name","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"group_type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.GroupType","io.confluent.connect.avro.Enum.SPEC_STORE":"SPEC_STORE","io.confluent.connect.avro.Enum.SPEC_SECONDARY_TEMPLATE":"SPEC_SECONDARY_TEMPLATE"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.GroupType"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SpecificAttributes"}}],"default":null},{"name":"target_market","type":["null",{"type":"record","name":"TargetMarket","fields":[{"name":"age_from","type":["null","QuantitativeValue"],"default":null},{"name":"age_to","type":["null","QuantitativeValue"],"default":null},{"name":"gender_segmentation","type":["null",{"type":"array","items":{"type":"record","name":"GenderSegmentation","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.GenderSegmentation"}}],"default":null},{"name":"recommended_age","type":["null","QuantitativeValue"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.TargetMarket"}],"default":null},{"name":"time_restrictions","type":["null",{"type":"record","name":"TimeRestriction","fields":[{"name":"is_alcohol","type":["null","boolean"],"default":null},{"name":"is_bread","type":["null","boolean"],"default":null},{"name":"is_cooled","type":["null","boolean"],"default":null},{"name":"is_frozen","type":["null","boolean"],"default":null},{"name":"is_required_preparation","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.TimeRestriction"}],"default":null},{"name":"transport_details","type":["null",{"type":"record","name":"TransportDetails","fields":[{"name":"bulky_description","type":["null","LookupTable"],"default":null},{"name":"is_bulky","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.TransportDetails"}],"default":null},{"name":"unique_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"width","type":["null","QuantitativeValue"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariant"}],"default":null},{"name":"launch_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"origin","type":["null",{"type":"record","name":"Origin","fields":[{"name":"identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Origin"}],"default":null},{"name":"publish_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"publish_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"refurbishment_level","type":["null","LookupTable"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":{"type":"record","name":"Seller","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Seller"}},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type_reference","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"volume_limit","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Offer"}}],"default":null},{"name":"pack_products","type":["null",{"type":"array","items":{"type":"record","name":"Bundle","fields":[{"name":"is_linkable","type":["null","boolean"],"default":null},{"name":"product","type":"Product"},{"name":"quantity","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Bundle"}}],"default":null},{"name":"pack_type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType","io.confluent.connect.avro.Enum.COLLECTION":"COLLECTION","io.confluent.connect.avro.Enum.AMBIENT":"AMBIENT","io.confluent.connect.avro.Enum.COORDINATED":"COORDINATED","io.confluent.connect.avro.Enum.LOTE":"LOTE","io.confluent.connect.avro.Enum.CONFIGURABLE":"CONFIGURABLE","io.confluent.connect.avro.Enum.FABRICANTE":"FABRICANTE"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType"}],"default":null},{"name":"pantone","type":["null","LookupTable"],"default":null},{"name":"piece_weight","type":["null","QuantitativeValue"],"default":null},{"name":"presentation_details","type":["null","PresentationDetails"],"default":null},{"name":"previous_gtins","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"priority_number","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"product_description","type":["null",{"type":"array","items":"I18nProductDescription"}],"default":null},{"name":"product_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"product_sorting_details","type":["null",{"type":"record","name":"ProductSortingDetails","fields":[{"name":"brand_sorting","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"category_sorting","type":["null",{"type":"array","items":{"type":"record","name":"ProductCategorySorting","fields":[{"name":"category","type":"Category"},{"name":"sort","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductCategorySorting"}}],"default":null},{"name":"size_sorting","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductSortingDetails"}],"default":null},{"name":"product_variants","type":["null",{"type":"array","items":"ProductVariant"}],"default":null},{"name":"provider","type":["null",{"type":"record","name":"Provider","fields":[{"name":"brand","type":["null","Brand"],"default":null},{"name":"description","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"postal_address","type":["null","PostalAddress"],"default":null},{"name":"telephone","type":["null","Telephone"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Provider"}],"default":null},{"name":"purchase_management_stock","type":["null","PurchaseManagementStock"],"default":null},{"name":"range","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.features.Range"],"default":null},{"name":"related_cross_sell_product_ids","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"related_services","type":["null",{"type":"array","items":"SignalService"}],"default":null},{"name":"robots_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"sale_type","type":["null","LookupTable"],"default":null},{"name":"service_agreement_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"sizes","type":["null",{"type":"array","items":"SizeInfo"}],"default":null},{"name":"special_handling_type","type":["null","SpecialHandlingType"],"default":null},{"name":"special_merchandise_indicator","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"specific_attribute_groups","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"specific_attributes","type":["null",{"type":"array","items":"SpecificAttributes"}],"default":null},{"name":"sub_brand","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"target_market","type":["null","TargetMarket"],"default":null},{"name":"time_restrictions","type":["null","TimeRestriction"],"default":null},{"name":"title_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"transport_details","type":["null","TransportDetails"],"default":null},{"name":"type","type":["null",{"type":"record","name":"ProductType","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"parent_product_type","type":["null","ProductType"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductType"}],"default":null},{"name":"unique_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"varies_by","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"warranty","type":["null",{"type":"record","name":"Warranty","fields":[{"name":"additional_info","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"duration","type":["null","QuantitativeValue"],"default":null},{"name":"url","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"urls","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Warranty"}],"default":null},{"name":"width","type":["null","QuantitativeValue"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Product"}}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_deleted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_recoded","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_point","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_type_badges","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.DeliveryTypes"],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"financing_data","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.FinancingData"],"default":null},{"name":"good_types","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.GoodType"}],"default":null},{"name":"has_european_conformity_certification","type":["null","boolean"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_non_technological","type":["null","boolean"],"default":null},{"name":"is_publish","type":["null","boolean"],"default":null},{"name":"is_return_allowed","type":["null","boolean"],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_searchable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariant"],"default":null},{"name":"launch_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"mixing_information","type":["null",{"type":"record","name":"MixingInformation","namespace":"es.eci.firefly.avro.mixer.canonical.model.mixer","fields":[{"name":"child_references","type":["null",{"type":"array","items":{"type":"record","name":"SiteOfferReference","namespace":"es.eci.firefly.avro.mixer.canonical.model.site","fields":[{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":{"type":"record","name":"ProductReference","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer","fields":[{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"pack_products","type":["null",{"type":"array","items":{"type":"record","name":"BundleReference","fields":[{"name":"product","type":"ProductReference"},{"name":"quantity","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BundleReference"}}],"default":null},{"name":"pack_type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType","io.confluent.connect.avro.Enum.COLLECTION":"COLLECTION","io.confluent.connect.avro.Enum.AMBIENT":"AMBIENT","io.confluent.connect.avro.Enum.COORDINATED":"COORDINATED","io.confluent.connect.avro.Enum.LOTE":"LOTE","io.confluent.connect.avro.Enum.CONFIGURABLE":"CONFIGURABLE","io.confluent.connect.avro.Enum.FABRICANTE":"FABRICANTE"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType"}],"default":null},{"name":"product_id","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"product_variants","type":["null",{"type":"array","items":{"type":"record","name":"ProductVariantReference","fields":[{"name":"bar_code_variants","type":["null",{"type":"array","items":{"type":"record","name":"BarCodeVariantReference","fields":[{"name":"gtin","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_main","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BarCodeVariantReference"}}],"default":null},{"name":"gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_variant_of","type":["null","ProductReference"],"default":null},{"name":"offers","type":["null",{"type":"array","items":{"type":"record","name":"OfferReference","fields":[{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":"ProductReference"}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"good_types","type":["null",{"type":"array","items":{"type":"record","name":"GoodType","namespace":"es.eci.firefly.avro.mixer.canonical.model.mixer","fields":[{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.mixer.GoodType"}}],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null","ProductVariantReference"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":{"type":"record","name":"SellerReference","fields":[{"name":"identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SellerReference"}},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.OfferReference"}}],"default":null},{"name":"previous_gtins","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"unique_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariantReference"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductReference"}}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"good_types","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.mixer.GoodType"}],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariantReference"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":"es.eci.firefly.avro.mixer.canonical.model.offer.SellerReference"},{"name":"site","type":["null",{"type":"record","name":"SiteInfo","fields":[{"name":"delivery_method","type":["null",{"type":"record","name":"DeliveryMethods","fields":[{"name":"available_centers","type":["null",{"type":"array","items":{"type":"record","name":"Center","fields":[{"name":"code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.Center"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.DeliveryMethods"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"parent","type":["null",{"type":"record","name":"Site","fields":[{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"parent","type":["null","Site"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.Site"}],"default":null},{"name":"price","type":["null",{"type":"record","name":"Price","fields":[{"name":"available_centers","type":["null",{"type":"array","items":"Center"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.Price"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.SiteInfo"}],"default":null},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.SiteOfferReference"}}],"default":null},{"name":"old_reference","type":["null","es.eci.firefly.avro.mixer.canonical.model.site.SiteOfferReference"],"default":null},{"name":"parent_reference","type":["null","es.eci.firefly.avro.mixer.canonical.model.site.SiteOfferReference"],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.mixer.MixingInformation"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}],"default":null},{"name":"origin","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.Origin"],"default":null},{"name":"publish_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"publish_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"refurbishment_level","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.LookupTable"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":"es.eci.firefly.avro.mixer.canonical.model.offer.Seller"},{"name":"site","type":"es.eci.firefly.avro.mixer.canonical.model.site.Site"},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type_reference","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"volume_limit","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.model.MixerOffer"}},{"name":"date","type":["null","long"],"default":null},{"name":"event_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"event_type","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.commons.event.EventType","io.confluent.connect.avro.Enum.CREATE":"CREATE","io.confluent.connect.avro.Enum.UPDATE":"UPDATE","io.confluent.connect.avro.Enum.UPSERT":"UPSERT","io.confluent.connect.avro.Enum.DELETE":"DELETE","io.confluent.connect.avro.Enum.TIMER":"TIMER"},"connect.name":"es.eci.firefly.avro.commons.event.EventType"}},{"name":"is_priority","type":"boolean","default":false},{"name":"metadata","type":["null",{"type":"array","items":{"type":"record","name":"EventMetadata","namespace":"es.eci.firefly.avro.commons.event","fields":[{"name":"date_created","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"origin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"trace_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"user","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.commons.event.EventMetadata"}}],"default":null},{"name":"process","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"partition","type":["null","int"],"default":null},{"name":"offset","type":["null","long"],"default":null},{"name":"timestamp","type":["null","long"],"default":null}],"connect.version":19,"connect.name":"es.eci.firefly.avro.mixer.event.MixerOfferEvent"},7ǻmf!Loffer(A41279013).publish_ends_extendedIVA02IGIC91 +01497001004340964247001471COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001004347101497004&includeAsWebNovelty +es_ESNovedadDVD"2021-09-29T22:00Z8434915528847Multicolor +es_ESMulticolorMulticolor +es_ESMulticolorMulticolor +es_ESMulticolor352633090 +es_ESMulticolor598507054 +20205 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png +es_ES6COLOR_MULTICOLOR_SECUNDARIO +es_ES6Color Multicolor SecundarioMulticolor +es_ESMulticolor0(2021-12-14T12:54:39Z +es_ES(PACK 2 BOXER POPELIN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008434915528847$000001519039300004TRADICIONAL +es_ES6COLOR_MULTICOLOR_SECUNDARIO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png2401812972260123284056 +MIRTOmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/2/00001269352/00001269352529mM1011.jpg +es_ES +Mirto +es_ESBoxers de tela999.39091454013 +es_ESBoxers de tela +2.000 +es_ESRopa Interior999.39072784013 +es_ESRopa Interior +2.000 +es_ES Interior y baño999.39072777013 +es_ES Interior y baño +4.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41279013 +es_ESBoxers de tela999.39091454013 +es_ESBoxers de tela +2.000 +es_ESRopa Interior999.39072784013 +es_ESRopa Interior +2.000 +es_ES Interior y baño999.39072777013 +es_ES Interior y baño +4.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNNN5143471600362624 +es_ES*CREACIONES MIRTO S.A.pCALLE EMILIO MUÑOZ.,57-28037 MADRID - MADRID (ESPAñA)  +es_ES^Pack de dos boxers de tela de hombre multicolor +es_ESPack de dos boxers de tela con abertura y botón, tejido 100% algodón. Cintura elástica con el interior forrado de felpa para una mayor comodidad.Ropa Interior. Por razones de higiene, solo se admiten cambios y devoluciones de artículos precintados de origen y que no hayan sido desprecintados.A41279013123284056 +MIRTO +es_ES +MIRTO5143471600362624 +es_ES*CREACIONES MIRTO S.A.pCALLE EMILIO MUÑOZ.,57-28037 MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize302 +es_ES^Pack de dos boxers de tela de hombre multicolor +es_ES^Pack de dos boxers de tela de hombre multicolor +es_ESPack de dos boxers de tela con abertura y botón, tejido 100% algodón. Cintura elástica con el interior forrado de felpa para una mayor comodidad.Ropa Interior. Por razones de higiene, solo se admiten cambios y devoluciones de artículos precintados de origen y que no hayan sido desprecintados. calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5Bcalificacion6T00N47936909052 +es_ES52E +es_ESEspañol479437090L +es_ESL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-15T03:12:35.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-16T03:12:35.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-05-10T04:17:34.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY + {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 150º","name":[{"value":"Planchado max 150º","locale":"es_ES"}],"external_identifier":"349576090","description":[{"value":"Planchado max 150º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Planchar máximo a 150º","locale":"es_ES"},{"value":"Engomar no máximo a 150º","locale":"pt_PT"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/09/___20536O1.png","size":"small"}],"description":[{"value":"Planchar máximo a 150º","locale":"es_ES"},{"value":"Engomar no máximo a 150º","locale":"pt_PT"}],"identifier":"20536","name":[{"value":"PLANCHAR_MAXIMO_A_150º","locale":"es_ES"}],"external_identifier":"598551054"}}{"identifier":"Limpieza con percloroetileno","name":[{"value":"Limpieza con percloroetileno","locale":"es_ES"}],"external_identifier":"484888090","description":[{"value":"Limpieza con percloroetileno","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Multiestampado","name":[{"value":"Multiestampado","locale":"es_ES"}],"external_identifier":"26027803090","description":[{"value":"Multiestampado","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Boxers de tela","name":[{"value":"Boxers de tela","locale":"es_ES"}],"external_identifier":"35251408090","description":[{"value":"Boxers de tela","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Ropa interior y Calcetines","name":[{"value":"Ropa interior y Calcetines","locale":"es_ES"}],"external_identifier":"2700612090","description":[{"value":"Ropa interior y Calcetines","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001519039300004(2022-05-10T04:17:34Z(2022-09-16T03:12:35Z(2022-09-15T03:12:35Z$001004347101497004001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore004H6d3af6bf-f7b5-4979-a431-4772650cfdd9 DELETE<2023-09-02T17:23:44.030441150Z4dataloader-mongo-kafka-job62023-09-02T17:23:50.973413Z(mixer-gtin-agr-kfreeH8d510ac8-003f-4aff-a208-087996c86ad662023-09-02T17:25:13.418344Z,mixer-gtin-calc-pcsflmHc64b2b7b-4068-477a-b289-5b292709bb8762023-09-02T17:25:14.608444Z,mixer-gtin-calc-pcsflmH4d2bcafa-feea-46a4-bcda-a194144e060062023-09-03T03:12:27.241572Z0mixer-product-calc-kfreeH12f8fbc8-1523-473c-a768-8b56df682377<2024-01-19T11:18:44.571341461Z$mixer-xsell-mixtriH9031b762-43e6-4c0a-92ad-13458f43afa562024-01-19T11:18:44.711178Z4mixer-packing-units-mixtriH0d9547c3-f666-45a4-87ca-29d5f557299062024-01-19T11:18:46.211192Z.mixer-offer-badge-mixbiH58b55b2d-b940-4840-8820-b5c36f62080262024-01-19T11:25:55.895067Z.mixer-offer-badge-mixbiH5958faf0-c5f6-4eb3-9fd3-ed56984f9f84(7Φ×cLoffer(A40778268).publish_ends_extendedIVA02IGIC91 +00080001088639986772001237(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001088623700080100&includeAsWebNovelty +es_ESNovedadDVD"2021-08-09T22:00Z3540513705957Natural +es_ESNaturalNatural +es_ESNatural +Beige +es_ES +Beige344754090 +es_ES +Beige599054054 +25619 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100629/___25619O1.png +es_ESCOLOR_BEIGE +es_ESColor Beige +Beige +es_ES +Beige0"2021-08-24T16:14Z +es_ES*SUJETADOR DE CAPACIDA158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003540513705957$000001517200940100TRADICIONAL +es_ESCOLOR_BEIGE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100629/___25619O1.png2401808447598152002056LOU +es_ESLou +es_ESModa mujer997.44571721011 +es_ESModa mujer 21.000 +es_ES30997.39154516011 +es_ES30 +4.000 +es_ESjCross - Contenedor Venta Privada NO Acumulable OI2223997.39128268011 +es_ESLContenedor Venta Privada no acumulableCDNN +es_ESLencería997.41964064011 +es_ESLencería +6.000 +es_ESModa Mujer997.41875780011 +es_ESModa Mujer 32.000 +es_ES,Cross - Contenedor 8DO997.41837795011 +es_ESContenedor 8DOCDNN +es_ES&Sujetadores con aro999.39072749013 +es_ES&Sujetadores con aro +8.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40778268 +es_ES&Sujetadores con aro999.39072749013 +es_ES&Sujetadores con aro +8.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN4872291600050500 +es_ES$LACELIER EUROPE SACALLE PZ DE EUROPA, 22-24. 3ª PLANTA,..-08902 HOSPITALET DE LLOBREGAT - BARCELONA (ESPAñA)  +es_ESBESTSELLER WHOLESALE SPAIN,S.L.fCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA)  +es_ESJTop de mujer estampado de manga larga +es_ESzTop estampado de manga larga con elástico y escote cuadrado.A43579418161273056ONLY +es_ESONLY6212151600502534 +es_ESTBESTSELLER WHOLESALE SPAIN,S.L._recargaNFTfCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize15264826 +es_ESJTop de mujer estampado de manga larga +es_ESJTop de mujer estampado de manga larga +es_ESzTop estampado de manga larga con elástico y escote cuadrado. calificacion1Acalificacion2Acalificacion3ROcalificacion4VVcalificacion5Bcalificacion622PDN47931509042 +es_ES42E +es_ESEspañol479445090XL +es_ESXL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02023-02-27T18:44:00.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-07-04T04:01:43.000ZONEate3liesiuooycBOOLEAN +falseMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}MANYaqundqcyqbyf5mTIMESTAMP02023-01-24T05:01:39.000ZONEafabpb3cbt6g3oTIMESTAMP02023-02-28T18:44:00.000ZONEakzd7vzeui6lmu STRINGDFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}{"identifier":"Puede limpiarse en seco","name":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"external_identifier":"4197325090","description":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Flores","name":[{"value":"Flores","locale":"es_ES"}],"external_identifier":"9338924090","description":[{"value":"Flores","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Tops","name":[{"value":"Tops","locale":"es_ES"}],"external_identifier":"347931090","description":[{"value":"Tops","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas, Blusas y Tops","name":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"external_identifier":"2700640090","description":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliéster","locale":"es_ES"},{"value":"Poliéster","locale":"pt_PT"},{"value":"Polyester","locale":"fr_FR"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliestere","locale":"it_IT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001529207520005(2022-07-04T04:01:43ZDVD"2023-02-28T18:44Z"2023-02-27T18:44Z$001029340102291005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H7e7301c0-398c-4314-8fc9-fdb5e0f1558d DELETE<2023-09-02T18:55:28.997089719Z4dataloader-mongo-kafka-job62023-09-02T19:09:11.584314Z(mixer-gtin-agr-kfreeHd0eaa117-5666-4667-9bb2-3008378916de62023-09-02T20:30:34.511563Z,mixer-gtin-calc-pcsflmHdc94e7d3-c062-42bc-ae50-06c2919e92a062023-09-02T20:30:36.416389Z,mixer-gtin-calc-pcsflmH808d54b9-fcd2-41c6-a1d9-74a6645d40b762023-09-03T03:03:00.233283Z0mixer-product-calc-kfreeHfefa2a90-03db-4ca0-b6a1-38d22e268749<2024-01-19T11:18:45.374513944Z$mixer-xsell-mixtriHff87faaa-5021-4019-8857-ca105be7272662024-01-19T11:18:45.527507Z4mixer-packing-units-mixtriH97ac0e03-f6aa-472c-98e4-f618cb0b125862024-01-19T11:18:46.234852Z.mixer-offer-badge-mixbiH2c59a7da-e718-47c5-9c62-75441db5ef9d62024-01-19T11:25:55.900076Z.mixer-offer-badge-mixbiH595ad237-d7d2-4e26-83cc-b9c8649b7975(7Φ×cLoffer(A41454354).publish_ends_extendedIVA02IGIC91 +12075001041542003144001144COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001041514412075005&includeAsWebNovelty +es_ESNovedadDVD +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2022-03-25T13:09:48Z +es_ES*TOP BAMBULA NUDO BAJO158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401814579948$000001519985430005TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401814579948124448056EASY WEARmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/1/00001269351/00001269351363mM1011.jpg +es_ESEasy Wear +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESRopa997.38159713011 +es_ESRopa +2.000 +es_ESModa Mujer997.38150773011 +es_ESModa Mujer +5.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41454354 +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0860056 +es_ES"HAMS GARMENTS LTD +es_ES:Body de mujer bambula a rayas +es_ES\Body de tirantes regulables , bambula a rayas.A41454354124448056EASY WEAR +es_ESEASY WEAR5410231600860056 +es_ES"HAMS GARMENTS LTD|CALLE HOUSE 72,ROAD 3,BLOCK B NIKET-,.- DHAKA - (BANGLADESH) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeS22-6077-T +es_ES:Body de mujer bambula a rayas +es_ES:Body de mujer bambula a rayas +es_ES\Body de tirantes regulables , bambula a rayas. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AD00N479307090 +40-42 +es_ES +40-42E +es_ESEspañol479437090L +es_ESL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-02T00:39:50.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-03T00:39:50.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-04-20T03:48:33.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Rayas","name":[{"value":"Rayas","locale":"es_ES"}],"external_identifier":"2655617090","description":[{"value":"Rayas","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bodys","name":[{"value":"Bodys","locale":"es_ES"}],"external_identifier":"347779090","description":[{"value":"Bodys","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Tirantes","name":[{"value":"Tirantes","locale":"es_ES"}],"external_identifier":"485212090","description":[{"value":"Tirantes","locale":"es_ES"}],"type_lookup":"1597"}MANYagio3trrjaqhgg ENTITY{"identifier":"100% Algodón","name":[{"value":"100% Algodón","locale":"es_ES"}],"external_identifier":"32382944090","description":[{"value":"100% Algodón","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas, Blusas y Tops","name":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"external_identifier":"2700640090","description":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"adbyfb4jfvuv5k":100.0,"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001519985430005(2022-04-20T03:48:33Z(2022-10-03T00:39:50Z(2022-10-02T00:39:50Z$001041514412075005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H19c7d0e1-abe3-4af4-b089-90f789f252fd DELETE<2023-09-02T17:29:31.890629230Z4dataloader-mongo-kafka-job62023-09-02T17:31:51.619799Z(mixer-gtin-agr-kfreeHd1862d52-475e-4347-bc1c-80778e9f6af962023-09-02T17:38:55.506458Z,mixer-gtin-calc-pcsflmH48382bb0-e88e-4748-a2ba-d54cbc5793c762023-09-02T17:38:58.311384Z,mixer-gtin-calc-pcsflmH3e183264-9a48-45ca-87a0-c6af7c80cabc62023-09-03T03:03:27.866027Z0mixer-product-calc-kfreeHfaa22db2-1145-4bde-ae84-a1f8aa905735<2024-01-19T11:18:45.584864889Z$mixer-xsell-mixtriHf83a3a8f-7147-4eae-8aef-da947f62864a62024-01-19T11:18:45.671129Z4mixer-packing-units-mixtriH7a17db0d-642d-4bb2-af60-00834a84e27562024-01-19T11:18:46.237383Z.mixer-offer-badge-mixbiHb6425e2c-fc91-4f49-b29e-d7477fee6b3362024-01-19T11:25:55.900770Z.mixer-offer-badge-mixbiHc9ce4e19-a568-45cf-9806-9eb7e4da109e(7Φ×cIVA02IGIC91 +3794500102023-02-20T07:10:21.147Z02939117188001102COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001029310237945272&includeAsWebNovelty +es_ESNovedadDVD"2018-01-18T23:00Z8718602727202 Grises +es_ES Grises Grises +es_ES GrisesGris +es_ESGris344777090 +es_ESGris5996500544940 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png +es_ESCOLOR_GRIS +es_ESColor GrisGris +es_ESGris0(2015-07-28T17:03:12Z +es_ESPANTALON DENI +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008718602727202$000001403413710272TRADICIONAL +es_ESCOLOR_GRIS +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png2401966004237153039056G STAR RAWmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/01/64/8/00001301648/00001301648916mM1011.jpg +es_ESG-Star Raw  +es_ES Vaqueros pitillo999.32181893013 +es_ES Vaqueros pitillo +4.000 +es_ESVaqueros999.8512864013 +es_ESVaqueros +6.000 +es_ES2014 Mujer999.2676238013 +es_ES +Mujer +1.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ESVaqueros999.8512864013 +es_ESVaqueros +6.000 +es_ES2014 Mujer999.2676238013 +es_ES +Mujer +1.000 +es_ESModa999.53895013 +es_ESModaNNN +es_ESVaqueros999.2680839013 +es_ESVaqueros 13.000 +es_ES +Mujer999.2676239013 +es_ES +Mujer 50.000 +es_ES2014 Mujer999.2676238013 +es_ES +Mujer +1.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ESVaqueros999.39090711013 +es_ESVaqueros 21.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ES Vaqueros pitillo999.39090716013 +es_ES Vaqueros pitillo +4.000 +es_ESVaqueros999.39090711013 +es_ESVaqueros 21.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ESVaqueros999.8521259013 +es_ESVaqueros 15.000 +es_ES2015 Joven Ella999.8452283013 +es_ESJoven Ella 22.000 +es_ESModa999.53895013 +es_ESModaNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A157110495022931600206029 +es_ES(G-STAR RAW DENIM SL.pCALLE DIEGO DE LEóN,58-28006 MADRID - MADRID (ESPAñA)  +es_ESBVaquero Skinny Midge Cody Slander +es_ESVaquero skinny que realza la silueta femenina que añade al diseño original cremalleras semiocultas en los bolsillos traseros adaptados. Tiene cierre delantero de cremallera y botón y trabillas en la cintura.A15711049153039056 G-STAR +es_ES G-STAR5022931600206029 +es_ES(G-STAR RAW DENIM SL.pCALLE DIEGO DE LEóN,58-28006 MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize60883-6132 +es_ESBVaquero Skinny Midge Cody Slander +es_ESBVaquero Skinny Midge Cody Slander +es_ESVaquero skinny que realza la silueta femenina que añade al diseño original cremalleras semiocultas en los bolsillos traseros adaptados. Tiene cierre delantero de cremallera y botón y trabillas en la cintura. calificacion1Acalificacion2Ocalificacion3RIcalificacion4VVcalificacion5CRcalificacion69100479259090 +36-38 +es_ES +36-38E +es_ESEspañol47921009027 +es_ES27477054090Americano +Talla47923409032 +es_ES32E +es_ESEspañol47923409032 +es_ES32477054090Americano +Largopz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-08-06T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-08-07T22:00:00.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02015-07-27T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYa5r36nvug7ald6 ENTITY{"identifier":"Pitillos","name":[{"value":"Pitillos","locale":"es_ES"}],"external_identifier":"2696231090","description":[{"value":"Pitillos","locale":"es_ES"}],"type_lookup":"1594"}MANYadla3f5bsg737w ENTITY{"identifier":"Joven Ella","name":[{"value":"Joven Ella","locale":"es_ES"}],"external_identifier":"347717090","description":[{"value":"Joven Ella","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Vaqueros","name":[{"value":"Vaqueros","locale":"es_ES"}],"external_identifier":"347852090","description":[{"value":"Vaqueros","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Gris","color_description":[{"value":"Gris","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Gris","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png","size":"small"}],"description":[{"value":"Gris","locale":"es_ES"}],"identifier":"4940","name":[{"value":"COLOR_GRIS","locale":"es_ES"}],"external_identifier":"599650054"},"identifier":"Gris","name":[{"value":"Gris","locale":"es_ES"}],"external_identifier":"344777090"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":70.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":28,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":2,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2015MANYawa5k5anmhgha2 ENTITY{"identifier":"Vaquero","name":[{"value":"Vaquero","locale":"es_ES"}],"external_identifier":"2656309090","description":[{"value":"Vaquero","locale":"es_ES"}],"type_lookup":"2501"}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001403413710272"2015-07-27T22:00Z"2019-08-07T22:00Z"2019-08-06T22:00Z$001029310237945272001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore272Haa0ae292-23c2-492f-a5c9-bd3d09be1554 DELETE<2023-09-02T17:14:52.343113864Z4dataloader-mongo-kafka-job62023-09-02T17:15:00.390766Z(mixer-gtin-agr-kfreeH28197eea-edb2-40bb-a4c2-515bc77da44a62023-09-02T17:15:05.109012Z,mixer-gtin-calc-pcsflmHadbf8b16-3f4a-42eb-bf56-ecd66d069e2962023-09-02T17:15:11.116349Z,mixer-gtin-calc-pcsflmH1daa5758-f651-40b8-88cf-9e7ba085679f62023-09-03T02:31:12.103133Z0mixer-product-calc-kfreeH2a786ee2-d5fb-4eaf-b05b-b9a49eb4f11c<2024-01-19T11:17:53.303779071Z$mixer-xsell-mixtriHd904e2ec-abd4-478e-9dd2-12e6aeb8066762024-01-19T11:17:53.519515Z4mixer-packing-units-mixtriHf628427b-e447-4315-9aae-b75f37b01a4562024-01-19T11:18:46.241315Z.mixer-offer-badge-mixbiH4b2c8eed-804c-4227-a6c2-a538687087f562024-01-19T11:25:55.904676Z.mixer-offer-badge-mixbiH824a3a24-92d6-411c-8205-32279381d1fb(7Φ×c,7ǻmf!IVA02IGIC91 +3547900102023-02-20T06:44:25.286Z097932370684001899COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001097989935479012&includeAsWebNovelty +es_ESNovedadDVD"2019-06-10T22:00Z2979899354793 +Rojos +es_ES +Rojos +Rojos +es_ES +RojosRojo +es_ESRojo344736090 +es_ESRojo599025054 +25344 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___25344O3.png +es_ESCOLO_ROJO +es_ESColo RojoRojo +es_ESRojo0(2019-08-26T16:23:15Z +es_ES*PANTALON FELPA BASICO +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401727186608$000001485628640012TRADICIONAL +es_ESCOLO_ROJO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___25344O3.png24017271866082307390056 +SFERAmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA01/201309/13/1377521437_1_.jpg +es_ES +Sfera +es_ESPantalones999.39089855013 +es_ESPantalones +2.000 +es_ESPantalones999.39089850013 +es_ESPantalones +6.000 +es_ESBebé Niño999.39073122013 +es_ESBebé Niño +4.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN +es_ESPantalones999.2680900013 +es_ESPantalones +7.000 +es_ES0Bebé Niño (0-36 meses)999.2680836013 +es_ES0Bebé Niño (0-36 meses) +5.000 +es_ES2014 Infantil999.2680809013 +es_ESInfantil +3.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A309715634827901600007336 +es_ES"SFERA JOVEN, S.A.jCALLE HERMOSILLA,112-28009 MADRID - MADRID (ESPAñA)  +es_EShPantalón de bebé niño Sfera felpa básico en rojo +es_ESPantalón felpa con detalle de osito. Bolsillos. Cintura ajustable. Algodón 100%.A309715632307390056 +SFERA +es_ES +SFERA4827901600007336 +es_ES"SFERA JOVEN, S.A.jCALLE HERMOSILLA,112-28009 MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize96B2251 +es_EShPantalón de bebé niño Sfera felpa básico en rojo +es_EShPantalón de bebé niño Sfera felpa básico en rojo +es_ESPantalón felpa con detalle de osito. Bolsillos. Cintura ajustable. Algodón 100%. +calificacion1Acalificacion2Acalificacion3M3calificacion4VVcalificacion5A14479092090 1 Año +es_ES 1 AñoE +es_ESEspañol479092090 1 Año +es_ES 1 Año477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-08-31T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-10-11T05:58:40.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02019-08-23T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347622090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Bebé Niño","name":[{"value":"Bebé Niño","locale":"es_ES"}],"external_identifier":"477515090","description":[{"value":"Bebé Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2019Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001485628640012"2019-08-23T22:00Z(2019-10-11T05:58:40Z"2019-08-31T22:00Z$001097989935479012001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore012H98aca9e0-fcd4-4308-a039-78a6331df9e4 DELETE<2023-09-02T17:16:30.605267087Z4dataloader-mongo-kafka-job62023-09-02T17:16:37.513066Z(mixer-gtin-agr-kfreeH2af7a65d-d229-4f38-8882-37ae2d242e9c62023-09-02T17:16:40.604460Z,mixer-gtin-calc-pcsflmHa8a62a24-77cf-4000-81b0-a1ae6a8fb3f962023-09-02T17:16:44.607324Z,mixer-gtin-calc-pcsflmH5e51bb53-bcbc-4096-be51-c283e7b8efc262023-09-02T21:53:42.271894Z0mixer-product-calc-kfreeHc1eac549-cc58-416f-8188-0ab658ee71ed<2024-01-19T11:17:53.638376280Z$mixer-xsell-mixtriH5e6e697c-1537-4913-b0c0-69042b1a60de62024-01-19T11:17:53.746222Z4mixer-packing-units-mixtriHb1092f17-a868-44c7-98ba-da0de78913d962024-01-19T11:18:46.321336Z.mixer-offer-badge-mixbiHbbe8e0b4-03f6-4695-b913-1701e3dda55f62024-01-19T11:25:55.985173Z.mixer-offer-badge-mixbiHc6850784-49e2-49b4-9fd3-d7f396240320(7Φ×cLoffer(A41265809).publish_ends_extendedIVA02IGIC91 +03326001096440571144001187COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001096418703326014&includeAsWebNovelty +es_ESNovedadDVD +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN"2021-09-28T22:00Z8720116153262Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2021-10-27T09:06:57Z +es_ESCAMISETA MC156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008720116153262$000001518973270014TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png2401812842495123709056TOMMY HILFIGERmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/0/00001269350/00001269350354mM1011.jpg +es_ESTommy Hilfiger +es_ESCamisetas999.39089905013 +es_ESCamisetas +4.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41265809 +es_ESCamisetas999.39089905013 +es_ESCamisetas +4.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN4890791600068585 +es_ES0TOMMY HILFIGER EUROPE BVCALLE CR LAUREA MIRO,403-08980 ST. FELIU DE LLOBREGAT - BARCELONA (ESPAñA)  +es_ESRCamiseta de niño de manga corta con logo +es_ESCamiseta de niño en manga corta y cuello redondo, fabricada en algodón orgánico. Color blanco con logo estampado en el pecho.A41265809123709056TOMMY HILFIGER +es_ESTOMMY HILFIGER4890791600068585 +es_ES0TOMMY HILFIGER EUROPE BVCALLE CR LAUREA MIRO,403-08980 ST. FELIU DE LLOBREGAT - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeKB0KB07012YBR +es_ESRCamiseta de niño de manga corta con logo +es_ESRCamiseta de niño de manga corta con logo +es_ESCamiseta de niño en manga corta y cuello redondo, fabricada en algodón orgánico. Color blanco con logo estampado en el pecho. +calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5VVPDN47912709014 Años +es_ES14 AñosE +es_ESEspañol19040058090 +13-14 +es_ES +13-1418171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-08-18T00:40:38.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-19T00:40:38.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-12-11T00:25:50.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","name":[{"value":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","locale":"es_ES"}],"external_identifier":"10460407090","description":[{"value":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Lavar a menos de 30º.","name":[{"value":"Lavar a menos de 30º.","locale":"es_ES"}],"external_identifier":"17585189090","description":[{"value":"Lavar a menos de 30º.","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar blanqueante","name":[{"value":"No usar blanqueante","locale":"es_ES"}],"external_identifier":"484894090","description":[{"value":"No usar blanqueante","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"351059090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518973270014(2021-12-11T00:25:50Z(2022-08-19T00:40:38Z(2022-08-18T00:40:38Z$001096418703326014001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore014H6e4592c8-c949-47e8-abc1-4474885c8ec7 DELETE<2023-09-02T17:15:17.409325748Z4dataloader-mongo-kafka-job62023-09-02T17:15:24.880994Z(mixer-gtin-agr-kfreeH23705c5b-85aa-492d-9218-06eb60c89e0962023-09-02T17:15:30.034813Z,mixer-gtin-calc-pcsflmHcbca619f-9c36-45ab-b4f5-fd5b1ca79ee562023-09-02T17:15:30.131755Z,mixer-gtin-calc-pcsflmHca9682cd-052e-47a6-a0f7-751d5d3640f362023-09-02T21:55:27.251616Z0mixer-product-calc-kfreeHd52b0b23-37c1-4a22-9602-af1fd8816aa4<2024-01-19T11:17:53.652653391Z$mixer-xsell-mixtriH4495f085-60b5-418e-a99e-e9857daefed662024-01-19T11:17:53.776005Z4mixer-packing-units-mixtriHf06f8092-fdf3-4942-9e29-064dba9cfa5862024-01-19T11:18:46.322605Z.mixer-offer-badge-mixbiH55228ef8-4dba-4cbb-a02c-88afdc3120dc62024-01-19T11:25:55.986343Z.mixer-offer-badge-mixbiH54b96f89-b0f9-4aa9-a866-2aa376de00ce(7Φ×cLoffer(A41275828).publish_ends_extendedIVA02IGIC91 +00031001041140395479001102COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001041110200031042&includeAsWebNovelty +es_ESNovedadDVD Verdes +es_ES Verdes Verdes +es_ES Verdes +Verde +es_ES +Verde347197090 +es_ES +Verde597003054 +11929 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___11929O2.png +es_ESCOLOR_VERDE +es_ESColor Verde +Verde +es_ES +Verde0(2021-10-07T12:58:29Z +es_ES,BAÑADOR CRUZADO ESTAM158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401812940436$000001519025730042TRADICIONAL +es_ESCOLOR_VERDE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___11929O2.png2401812940436126815056ENFASISmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/0S/00/0/0000000S000/0000000S000550mM1011.jpg +es_ESÉnfasis +es_ESBañadores999.39089951013 +es_ESBañadores +1.000 +es_ESBañadores999.39089936013 +es_ESBañadores +7.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN 240181625371624018162536622401816253709240181625345724018162534642401816253471A41619086158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41275828 +es_ESBañadores999.39089951013 +es_ESBañadores +1.000 +es_ESBañadores999.39089936013 +es_ESBañadores +7.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN5934321600942839 +es_ESMELBIMAQ, S.L.vCALLE JUAN LISBONA ZAPATA,8-29700 VELEZ - MALAGA (ESPAñA)  +es_ESBBañador cruzado estampado marino +es_ESBañador cruzado estampado marino, con forro al tono mate. Copa fija y goma bajo el pecho.A41275828126815056ENFASIS +es_ESENFASIS5934321600942839 +es_ESMELBIMAQ, S.L.vCALLE JUAN LISBONA ZAPATA,8-29700 VELEZ - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeET22PR.BA04.03B +es_ESBBañador cruzado estampado marino +es_ESBBañador cruzado estampado marino +es_ESBañador cruzado estampado marino, con forro al tono mate. Copa fija y goma bajo el pecho. +calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5AH00N042E +es_ESEspañol042477062090Español +Talla479429090B +es_ESBE +es_ESEspañol479429090B +es_ESB477062090EspañolCopapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-15T00:41:30.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-16T00:41:30.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-16T05:04:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa3kybygykw5doe ENTITY{"identifier":"Preformado","name":[{"value":"Preformado","locale":"es_ES"}],"external_identifier":"5290004090","description":[{"value":"Preformado","locale":"es_ES"}],"type_lookup":"2505"}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Fantasía","name":[{"value":"Fantasía","locale":"es_ES"}],"external_identifier":"25521449090","description":[{"value":"Fantasía","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bañadores","name":[{"value":"Bañadores","locale":"es_ES"}],"external_identifier":"349580090","description":[{"value":"Bañadores","locale":"es_ES"}],"type_lookup":"1617"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Clásico","name":[{"value":"Clásico","locale":"es_ES"}],"external_identifier":"347631090","description":[{"value":"Clásico","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYagio3trrjaqhgg ENTITY{"identifier":"Fibras sintéticas","name":[{"value":"Fibras sintéticas","locale":"es_ES"}],"external_identifier":"22937672090","description":[{"value":"Fibras sintéticas","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Bañadores","name":[{"value":"Bañadores","locale":"es_ES"}],"external_identifier":"2858983090","description":[{"value":"Bañadores","locale":"es_ES"}],"type_lookup":"1599"}MANYaj3ufdvuwowrlw ENTITY{"identifier":"Con foam","name":[{"value":"Con foam","locale":"es_ES"}],"external_identifier":"2696270090","description":[{"value":"Con foam","locale":"es_ES"}],"type_lookup":"1601"}ONEastcg34k65osv2 STRING[{"locale":"en_GB","value":"PROMO COLLECTION"},{"locale":"fr_FR","value":"PROMO COLLECTION"},{"locale":"pt_PT","value":"PROMO COLLECTION"},{"locale":"es_ES","value":"PROMO COLLECTION"}]MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":74,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":26,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001519025730042"2022-03-16T05:04Z(2022-08-16T00:41:30Z(2022-08-15T00:41:30Z$001041110200031042001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore042Hd035f209-6ce1-4aaa-9fca-89af6f26a458 DELETE<2023-09-02T17:14:41.459751209Z4dataloader-mongo-kafka-job62023-09-02T17:14:47.440822Z(mixer-gtin-agr-kfreeH3dac8b1b-eded-4887-af94-9d0b5a39d69062023-09-02T17:14:53.222867Z,mixer-gtin-calc-pcsflmH02801625-54d1-4063-be3c-c22106d3578462023-09-02T17:14:59.310593Z,mixer-gtin-calc-pcsflmH99e00eb7-e389-42c0-826b-423cdae9069f62023-09-03T02:36:01.200787Z0mixer-product-calc-kfreeH4bd2988a-0a7a-4e66-a978-22033f23475d<2024-01-19T11:17:54.372927487Z$mixer-xsell-mixtriH565e2f5c-8e34-40fa-b6d4-822db57f6a1d62024-01-19T11:17:54.637841Z4mixer-packing-units-mixtriH8c5281ff-6696-4d51-be47-67ba91907e0162024-01-19T11:18:46.427032Z.mixer-offer-badge-mixbiH50be313c-75a9-4794-a91f-c69f8cefcc5c62024-01-19T11:25:55.989633Z.mixer-offer-badge-mixbiHfa2bf236-cfc9-44fd-883d-e84e99d7cdef(7Φ×cLoffer(A40673932).publish_ends_extendedIVA02IGIC92 +78523001019541257196001226COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001019522678523 &includeAsWebNovelty +es_ESNovedadDVD"2021-07-29T22:00Z8056597516822Marrones +es_ESMarronesMarrones +es_ESMarronesMarrón +es_ESMarrón344718090 +es_ESMarrón5995980544536 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4536O3.png +es_ESCOLOR_MARRON +es_ESColor MarrónMarrón +es_ESMarrón0(2022-01-12T09:12:53Z +es_ES*GAFA SOL 0RB4351 601/155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008056597516822$000000000151678535TRADICIONAL +es_ESCOLOR_MARRON +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4536O3.png2401807346502897538056RAY BAN +es_ESRay-Ban +es_ESGafas de sol999.39072275013 +es_ESGafas de sol +8.000 +es_ESAccesorios999.39072257013 +es_ESAccesorios +3.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ESGafas de sol999.39072392013 +es_ESGafas de sol +2.000 +es_ESAccesorios999.39072300013 +es_ESAccesorios +4.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40673932 +es_ESGafas de sol999.39072275013 +es_ESGafas de sol +8.000 +es_ESAccesorios999.39072257013 +es_ESAccesorios +3.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN4912831600090118 +es_ES,LUXOTTICA SPAIN S.L.U.CALLE LG PLACA DE LA PAU,S-N ED 3 PL,4-08940 CORNELLA DE LLOBREGAT - BARCELONA (ESPAñA)  +es_ESvGafas de sol rectangulares en havana con lentes polarizadas +es_ESGafas modelo 0RB4351 con montura rectangular inyectada en color havana. Tiene lentes polarizadas en color marrón.A40673932897538056RAY BAN +es_ESRAY BAN4912831600090118 +es_ES,LUXOTTICA SPAIN S.L.U.CALLE LG PLACA DE LA PAU,S-N ED 3 PL,4-08940 CORNELLA DE LLOBREGAT - BARCELONA (ESPAñA) 998.00194 +es_ESComplementos998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos0RB4351 +es_ESvGafas de sol rectangulares en havana con lentes polarizadas +es_ESvGafas de sol rectangulares en havana con lentes polarizadas +es_ESGafas modelo 0RB4351 con montura rectangular inyectada en color havana. Tiene lentes polarizadas en color marrón. calificacion1Acalificacion2Acalificacion3DDcalificacion4VVcalificacion5NScalificacion6FI06Npeymj6wu3nmofgpler4twpwa2rdqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-06T00:42:53.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-07T00:42:53.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-01-13T05:41:50.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE*ONEa23cmjahzrba2o ENTITY{"identifier":"Inyectado","name":[{"value":"Inyectado","locale":"es_ES"}],"external_identifier":"6122353090","description":[{"value":"Inyectado","locale":"es_ES"}],"type_lookup":"1572"}ONEa24pex3eetpyqa ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEa2yflkefrj74pa ENTITY{"identifier":"Policarbonato","name":[{"value":"Policarbonato","locale":"es_ES"}],"external_identifier":"472416090","description":[{"value":"Policarbonato","locale":"es_ES"}],"type_lookup":"1571"}ONEa5nsx33mjujuu4 ENTITY{"identifier":"Rectangulares","name":[{"value":"Rectangulares","locale":"es_ES"}],"external_identifier":"34709072090","description":[{"value":"Rectangulares","locale":"es_ES"}],"type_lookup":"2656090"}MANYa5wg3q7jlozdji ENTITY{"identifier":"Inyectado","name":[{"value":"Inyectado","locale":"es_ES"}],"external_identifier":"26338893090","description":[{"value":"Inyectado","locale":"es_ES"}],"type_lookup":"1633"}MANYa5xfo2abga2eme NUMBER2022ONEaa72dm3yz6vb5u ENTITY{"identifier":"Gafas de sol","name":[{"value":"Gafas de sol","locale":"es_ES"}],"external_identifier":"472320090","description":[{"value":"Gafas de sol","locale":"es_ES"}],"type_lookup":"1619"}ONEacu7fudzmosqju ENTITY{"identifier":"Polarizadas","name":[{"value":"Polarizadas","locale":"es_ES"}],"external_identifier":"34539809090","description":[{"value":"Polarizadas","locale":"es_ES"}],"type_lookup":"2657090"}ONEadcnwupelqbrxs ENTITY{"identifier":"Categoría Filtro 3 / Tipo de Filtro P / UVA UVB","name":[{"value":"Categoría Filtro 3 / Tipo de Filtro P / UVA UVB","locale":"es_ES"}],"external_identifier":"41634628090","description":[{"value":"Categoría Filtro 3 / Tipo de Filtro P / UVA UVB","locale":"es_ES"}],"type_lookup":"1561"}ONEadjkx6doqhphzu ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEaf2s6bsybax3cu ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEah2u2hrwv7s5je ENTITY{"identifier":"Inyectado","name":[{"value":"Inyectado","locale":"es_ES"}],"external_identifier":"6122353090","description":[{"value":"Inyectado","locale":"es_ES"}],"type_lookup":"1572"}ONEajh5lexpkiayrw NUMBER59ONEalrx3pcoyv6lwy ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEanxumtnaxc7bmw ENTITY{"identifier":"Gafas de sol","name":[{"value":"Gafas de sol","locale":"es_ES"}],"external_identifier":"472453090","description":[{"value":"Gafas de sol","locale":"es_ES"}],"type_lookup":"1573"}ONEaqsyynpf64ahyc NUMBER +140.0ONEauf5gizlxivgeg ENTITY{"identifier":"Marrón","name":[{"value":"Marrón","locale":"es_ES"}],"external_identifier":"27604449090","description":[{"value":"Marrón","locale":"es_ES"}],"type_lookup":"2605090"}ONEawbars6tp3y3dc NUMBER17ONEaykfu4ofworlxo NUMBER45.5MANYaz2gbwdmqlkyim ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}MANYazrazbd5hx4qa4 ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"} Complementos_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000151678535(2022-01-13T05:41:50Z(2022-10-07T00:42:53Z(2022-10-06T00:42:53Z$001019522678523 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hc7901387-83a2-4ce1-8547-dd384279dfcf DELETE<2023-09-02T17:30:20.419042094Z4dataloader-mongo-kafka-job62023-09-02T17:34:03.414783Z(mixer-gtin-agr-kfreeH0b6ea120-8223-4eb7-91ce-49626f6173a162023-09-02T17:40:05.815181Z,mixer-gtin-calc-pcsflmHb0ea2f89-f235-4ed9-ac0b-5c880a11a66c62023-09-02T17:40:09.311607Z,mixer-gtin-calc-pcsflmHc52de68e-03c6-4b38-9765-523117dc73ec62023-09-02T23:17:59.243941Z0mixer-product-calc-kfreeHc311f4c6-8949-4631-b7ba-4f20ece0bec1<2024-01-19T11:18:45.638234783Z$mixer-xsell-mixtriH32feae17-6ca3-4628-9eb3-387896eaf92662024-01-19T11:18:45.871268Z4mixer-packing-units-mixtriHca6afabd-45d6-4c74-98de-3092c7dcfbb862024-01-19T11:18:46.964840Z.mixer-offer-badge-mixbiH5e01fb5f-159a-4126-81f9-9cf328037e4062024-01-19T11:25:55.993830Z.mixer-offer-badge-mixbiH310dd394-2f62-4b68-a386-e6d56c024618(7Φ×cLoffer(A17361728).publish_ends_extendedIVA02IGIC91 +03750001007231102968001801COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001007280103750 &includeAsWebNovelty +es_ESNovedadDVD +es_ES(Restricción cristal12178924090(Restricción cristal +es_ES(Restricción cristalSPECIAL_GOOD"2015-11-25T23:00Z2072801037507 Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2019-01-31T15:35:30Z +es_ESDECORACION27 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401983538418$000000000141506608TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png240198353841819272314056SARGADELOS +es_ESSargadelos +es_ES&Figuras decorativas999.194896013 +es_ES&Figuras decorativas +2.000 +es_ES&Objetos Decorativos999.53045013 +es_ESDecoración 28.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN27 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A17361728 +es_ES&Figuras decorativas999.194896013 +es_ES&Figuras decorativas +2.000 +es_ES&Objetos Decorativos999.53045013 +es_ESDecoración 28.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN0430298 +es_ES8PORCELANA DE SARGADELOS S.L. +es_ESRFigura decorativa Botijo n° 5 Sargadelos +es_ESFigura decorativa con forma de botijo de la firma gallega Sargadelos. Un diseño elegante de líneas suaves y redondeadas, decorado con un original patrón geométrico en los colores característicos de la firma, el azul y el blanco.Una pieza llena de tradición y color con la que añadir un toque de estilo a la decoración.A1736172819272314056SARGADELOS +es_ESSARGADELOS0430298 +es_ES8PORCELANA DE SARGADELOS S.L.998.00208 +es_ESHDecoracion, Orden en casa y Mascotas998.00206 +es_ES +Hogar998 +es_ES@Jerarquía de Ficha de Productos BOTIJO +es_ESRFigura decorativa Botijo n° 5 Sargadelos +es_ESRFigura decorativa Botijo n° 5 Sargadelos +es_ESTradicional233777090Tradicional +es_ESTradicional +10107 +es_ESFigura decorativa con forma de botijo de la firma gallega Sargadelos. Un diseño elegante de líneas suaves y redondeadas, decorado con un original patrón geométrico en los colores característicos de la firma, el azul y el blanco.Una pieza llena de tradición y color con la que añadir un toque de estilo a la decoración. calificacion1A4calificacion2Icalificacion3Ecalificacion4EXcalificacion5EXcalificacion6EE07pdvndags3xde3ipler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"010","name":[{"value":"010","locale":"es_ES"}],"external_identifier":"233767090","description":[{"value":"Gestión Automática - Publica despublicadas con stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-13T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-23T12:04:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02019-09-30T08:19:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa2o4r6xvuyo4pc ENTITY{"identifier":"NO","name":[{"value":"NO","locale":"es_ES"}],"external_identifier":"21516242090","description":[{"value":"NO","locale":"es_ES"}],"type_lookup":"2564"}ONEaapqkjspt4nt2s NUMBER30.0ONEab564tauput3qm ENTITY{"identifier":"Figuras","name":[{"value":"Figuras","locale":"es_ES"}],"external_identifier":"234919090","description":[{"value":"Figuras","locale":"es_ES"}],"type_lookup":"10042"}MANYaele2etwqje2se ENTITY{"color_code":"Azul","color_description":[{"value":"Azul","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Azul","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png","size":"small"}],"description":[{"value":"Azul","locale":"es_ES"}],"identifier":"15915","name":[{"value":"COLOR_AZUL","locale":"es_ES"}],"external_identifier":"598455054"},"identifier":"Azul","name":[{"value":"Azul","locale":"es_ES"}],"external_identifier":"347189090"}MANYafgxijqzroklyw ENTITY {"identifier":"Porcelana","name":[{"value":"Porcelana","locale":"es_ES"}],"external_identifier":"391979090","description":[{"value":"Porcelana","locale":"es_ES"}],"type_lookup":"194","glossary":{"term":[{"value":"Porcelana","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Es un tipo de material cerámico, tradicionalmente blanco, que se obtiene de una pasta blanca compuesta de caolín, feldespato y cuarzo, cocida a 1200 grados centígrados. Muy utilizada en vajillas y piezas decorativas debido a su dureza, acabado, transparencia, impermeabilidad y resistencia a choques térmicos.","locale":"es_ES"}],"identifier":"12652","name":[{"value":"PORCELANA","locale":"es_ES"}],"external_identifier":"5290322054"}}MANYaor3k4rf26tngs STRING[{"locale":"es_ES","value":["Sargadelos coge el nombre de la aldea de Lugo donde fundó su primera fábrica y donde tiene su centro de producción. La firma gallega es conocida por su inconfundible porcelana, que combina tradición y modernidad, y por sus diseños relacionados con la cultura y tradición gallega en azules y blancos."]}]ONEaw6y2qqrk6pavk ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}Decoracion_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000141506608"2019-09-30T08:19Z"2022-09-23T12:04Z"2022-09-13T22:00Z$001007280103750 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Ha2a1b798-f74e-4337-ad78-df70d97af8da DELETE<2023-09-02T17:27:59.101365843Z4dataloader-mongo-kafka-job62023-09-02T17:28:16.443333Z(mixer-gtin-agr-kfreeH26a45468-23f0-4105-9e36-f2f18e6c033262023-09-02T17:28:35.611550Z,mixer-gtin-calc-pcsflmH559aa66d-55b3-41c7-a66c-754cfbbc473062023-09-02T17:28:36.517024Z,mixer-gtin-calc-pcsflmHb438f587-f93c-4e50-93ec-6bdffb76c60c62023-09-03T03:21:44.868549Z0mixer-product-calc-kfreeH8e609334-88a9-465a-80b0-8e28fb661662<2024-01-19T11:18:46.071703707Z$mixer-xsell-mixtriH63b06f6f-10e9-4170-b6ca-42ceca9fd57062024-01-19T11:18:46.259485Z4mixer-packing-units-mixtriHf2608be0-d61f-4015-ac8c-2a892721249962024-01-19T11:18:47.014870Z.mixer-offer-badge-mixbiH0f0153b3-8727-40d0-9cd6-4e2bf937ea5062024-01-19T11:25:55.994866Z.mixer-offer-badge-mixbiH10961bcf-e1ac-4c85-b9c0-2e4f4f77c88d(7Φ×cLoffer(A45610241).publish_ends_extendedIVA02IGIC91 +46608001067944185948001702(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001067970246608070"2022-04-25T22:00Z4065427411866 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2022-10-27T07:18:01Z +es_EST.ADIDAS56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004065427411866$000001529396070070TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401836583206123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas + +es_ESDDeportes - Contenedor rebajas OI22997.44869638011 +es_ESDDeportes - Contenedor rebajas OI22N +es_ESRunning999.14619892013 +es_ESRunning +2.000 +es_ES ZapatillasyBotas999.12473896013 +es_ES$Zapatillas y Botas +2.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESZapatillas999.53819013 +es_ESZapatillas +2.000 +es_ESRunning999.53818013 +es_ESRunning 16.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESCalzado999.53678013 +es_ESCalzado +7.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESPDeportes - Contenedor 2as Rebajas OI2223997.45082266011 +es_ES:Contenedor 2as Rebajas OI2223N56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A45610241 +es_ESRunning999.14619892013 +es_ESRunning +2.000 +es_ES ZapatillasyBotas999.12473896013 +es_ES$Zapatillas y Botas +2.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN5788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ES\Zapatillas de running de mujer EQ21 Run adidas +es_ESCorre con confianza con esta zapatilla de running adidas. La parte superior transpirable mantiene los pies frescos en las carreras de larga distancia. La mediasuela con amortiguación ligera te ofrece una pisada más cómoda desde el principio hasta el final de la carrera.Horma clásica$Cierre de cordones`Estabilizadores de TPU en el talón y el lateral"Mediasuela Bounce:Panel acolchado en el tobillo@Parte superior de malla técnicaA45610241123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize GY2209 +es_ES\Zapatillas de running de mujer EQ21 Run adidas +es_ES\Zapatillas de running de mujer EQ21 Run adidas9999999.000 +es_ESCorre con confianza con esta zapatilla de running adidas. La parte superior transpirable mantiene los pies frescos en las carreras de larga distancia. La mediasuela con amortiguación ligera te ofrece una pisada más cómoda desde el principio hasta el final de la carrera.Horma clásica$Cierre de cordones`Estabilizadores de TPU en el talón y el lateral"Mediasuela Bounce:Panel acolchado en el tobillo@Parte superior de malla técnica calificacion1Acalificacion2Ecalificacion3M5calificacion4VVcalificacion5AAcalificacion6MO00N47930609040 y 2/3 +es_ES40 y 2/3E +es_ESEspañol4793990907 +es_ES718171618090Fabricante +Talla +pler4twpwa2rdqphm44qlzhmwa2ypwe2kceprh5w3apeohixr7rbw25wpzemnwoecgod3uONEadxazarzusz3teBOOLEAN +falseONEatos7dqm35n3ma NUMBER9999999Comunes_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02023-01-16T02:12:09.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-10-22T22:00:00.000ZONEate3liesiuooycBOOLEANtrueONEafabpb3cbt6g3oTIMESTAMP02023-01-30T02:47:21.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa7jpc7s7go77wi ENTITY{"identifier":"Textil","name":[{"value":"Textil","locale":"es_ES"}],"external_identifier":"392162090","description":[{"value":"Textil","locale":"es_ES"}],"type_lookup":"1633"}ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYajmbvqrupncdje STRING[{"locale":"en_GB","value":["Beginner (up to 10 km)"]},{"locale":"fr_FR","value":["Initiation (jusqu'à 10 km)"]},{"locale":"es_ES","value":["Iniciación (hasta 10 km)"]}]MANYaks4jlgaxtjowg ENTITY{"identifier":"Goma","name":[{"value":"Goma","locale":"es_ES"}],"external_identifier":"477871090","description":[{"value":"Goma","locale":"es_ES"}],"type_lookup":"1633"}MANYamzex7cmn57eei ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Malla","name":[{"value":"Malla","locale":"es_ES"}],"external_identifier":"10422274090","description":[{"value":"Malla","locale":"es_ES"}],"type_lookup":"1633"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Running","name":[{"value":"Running","locale":"es_ES"}],"external_identifier":"373583090","description":[{"value":"Running","locale":"es_ES"}],"type_lookup":"1620"}ONEauur46vhpycka4 ENTITY{"identifier":"Deportivas mujer","name":[{"value":"Deportivas mujer","locale":"es_ES"}],"external_identifier":"373605090","description":[{"value":"Deportivas mujer","locale":"es_ES"}],"type_lookup":"1611"}Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001529396070070"2022-10-22T22:00ZDVD(2023-01-30T02:47:21Z(2023-01-16T02:12:09Z$001067970246608070001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore07008H08127d3c-10cb-4a9c-86e0-eb3d026046da DELETE<2023-09-02T17:48:24.702058198Z4dataloader-mongo-kafka-job62023-09-02T18:14:07.291008Z(mixer-gtin-agr-kfreeH84b2fce0-0b83-41a3-9231-175230e03b0f62023-09-02T18:30:42.717618Z,mixer-gtin-calc-pcsflmH1d8c1c9a-30be-4de0-858f-08b3db42579e62023-09-02T18:30:54.712741Z,mixer-gtin-calc-pcsflmHaded4fe4-1413-44cd-a2e1-35f62719021d62023-09-03T03:18:44.611451Z0mixer-product-calc-kfreeH65005acb-92e9-4b4f-9848-935e1fda6fd4<2024-01-19T11:18:46.068747699Z$mixer-xsell-mixtriHa63c748b-c4f4-46ad-88a3-9f8bed9e033c62024-01-19T11:18:46.342731Z4mixer-packing-units-mixtriH977fa71d-7494-4eb4-873e-86baf992b7f062024-01-19T11:18:46.825951Z.mixer-offer-badge-mixbiH7c68e1be-e49a-4f46-9b0e-eb45d098032f62024-01-19T11:25:56.001601Z.mixer-offer-badge-mixbiH09e00a18-46d3-4031-983e-62904fd74103(7Φ×cLoffer(A44110101).publish_ends_extendedIVA02IGIC91 +01099001004243447589001255COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001004225501099504&includeAsWebNovelty +es_ESNovedadDVD +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN Grises +es_ES Grises Grises +es_ES GrisesGris oscuro +es_ESGris oscuro347603090 +es_ESGris Oscuro5996810545055 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___5055O2.png +es_ES"COLOR_GRIS_OSCURO +es_ES"Color Gris OscuroGris oscuro +es_ESGris oscuro0(2022-08-17T09:33:44Z +es_ES*PANTALON CINCO BOLSIL155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401841488428$000001531566890504TRADICIONAL +es_ES"COLOR_GRIS_OSCURO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___5055O2.png2401841488428129614056 DUSTINmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/2/00001269352/00001269352440mM1011.jpg +es_ES Dustin +es_ESVaqueros999.39072585013 +es_ESVaqueros +7.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A44110101 +es_ESVaqueros999.39072585013 +es_ESVaqueros +7.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN0877415 +es_ES,STITCH N STYLE PVT LTD +es_ES2Vaquero de hombre classic +es_ESVaquero con cremallera y botón en el delantero. Dos bolsillos de parche. Patrón classic.Classic FitConfortables y elegantes. Caja y tiro medios. Ancho de pierna recto. +pt_PTClassic FitA44110101129614056 DUSTIN +es_ES DUSTIN0877415 +es_ES,STITCH N STYLE PVT LTD998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize27L8251E +es_ES2Vaquero de hombre classic +es_ES2Vaquero de hombre classic +es_ESVaquero con cremallera y botón en el delantero. Dos bolsillos de parche. Patrón classic.Classic FitConfortables y elegantes. Caja y tiro medios. Ancho de pierna recto. +pt_PTClassic Fit +calificacion1Acalificacion2Acalificacion3E5calificacion4VVcalificacion5AC00N47936309050 +es_ES50E +es_ESEspañol47936309050 +es_ES50477062090Español +Talla199071140904 Largo +es_ES4 LargoE +es_ESEspañol199071140904 Largo +es_ES4 Largo477062090Español +Largopz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-14T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-15T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}ONEa4aig6savkv75m STRING[{"locale":"es_ES","value":"Cremallera y botón"},{"locale":"pt_PT","value":"Fecho de correr e botão"},{"locale":"en_GB","value":"Zip and button"},{"locale":"fr_FR","value":"Fermeture éclair et bouton"}]MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYa5r36nvug7ald6 ENTITY{"identifier":"Classic","name":[{"value":"Classic","locale":"es_ES"}],"external_identifier":"12970401090","description":[{"value":"Classic","locale":"es_ES"}],"type_lookup":"1594"}ONEabf2vvifj26pzi ENTITY{"identifier":"Largo","name":[{"value":"Largo","locale":"es_ES"}],"external_identifier":"2655628090","description":[{"value":"Largo","locale":"es_ES"}],"type_lookup":"2507"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Sport","name":[{"value":"Sport","locale":"es_ES"}],"external_identifier":"347623090","description":[{"value":"Sport","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Vaqueros","name":[{"value":"Vaqueros","locale":"es_ES"}],"external_identifier":"347852090","description":[{"value":"Vaqueros","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":98,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":2,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2023Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001531566890504"2022-08-15T22:00Z"2022-08-14T22:00Z$001004225501099504001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore504Hd86c0ecd-b8a0-490f-a60e-b062fddbfc8d DELETE<2023-09-02T17:13:51.960747578Z4dataloader-mongo-kafka-job62023-09-02T17:13:56.671850Z(mixer-gtin-agr-kfreeH3ca85086-0ea4-4bec-8c0f-1c42fc0c231f62023-09-02T17:14:12.509682Z,mixer-gtin-calc-pcsflmH25ef7699-da55-4f62-a6d5-b65fc90f092262023-09-02T17:14:17.019947Z,mixer-gtin-calc-pcsflmH19572993-14e4-4652-823b-291904c8ffc862023-09-02T21:39:53.059976Z0mixer-product-calc-kfreeH3fa5ef6b-243d-4a9f-bf6c-f63c5cf79e7b<2024-01-19T11:17:55.418355281Z$mixer-xsell-mixtriH882b5c5c-8933-4ff4-b69c-9c8a54fb83f862024-01-19T11:17:55.557397Z4mixer-packing-units-mixtriHab1315df-389d-4e2f-aabd-eea45a18b29a62024-01-19T11:18:46.746080Z.mixer-offer-badge-mixbiH1f6d5edb-56c9-46bf-b6b7-86b2650b110b62024-01-19T11:25:56.003557Z.mixer-offer-badge-mixbiH08fa0213-954b-4d40-94fb-93c95b9dfd6b(7Φ×c,7ǻmf!IVA08IGIC90"2004-11-29T23:00Z +8371100102023-03-21T03:24:32.294Z0065748540001202COMPRA EN FIRME +es_ESCOMPRA EN FIRME*LECTURAS RECOMENDADAS +es_ES*LECTURAS RECOMENDADASSTERLING +es_ESSTERLING$001006520283711 "2004-11-29T23:00Z9788435039963"2011-12-13T23:00Z20652028371110(2011-09-03T04:50:32Z +es_ES Libros274977090 Libros3959788435039963$0000000001007649222401176551460131535056 EDHASA +es_ES EDHASA +es_ES"Novela histórica999.6841142013 +es_ES"Novela histórica 37.000 +es_ES Libros999.54302013 +es_ES LibrosNN +es_ES Libros274977090 Libros395A36872785585191602030734 +es_ES EDHASA ,- - ()  +es_ES&Salvaje (Tapa dura) +es_ES Jemmy Button es el más conocido de los indígenas de Patagonia que fueron trasladados a Inglaterra en las primeras décadas del siglo XIX con el propósito de estudiarlos y situarlos en la cadena evolutiva del hombre. Se convirtieron en poco menos que objetos de investigación científica, al tiempo que en atracción de feria. Button fue el que mostró una mayor capacidad de adaptación y el que mayores logros obtuvo en su aprendizaje de la lengua inglesa y las costumbres británicas, y por elo es también el más conocido, pero acabó sus días acusado de la muerte de toda la tripulación de una goleta.A través de su historia, Nick Hazlewood traza una imagen muy poco complaciente del darwinismo, de la frenología y sobre todo de la política de la Corona británica en Argentina, que acabó en una vorágine de exterminio de los indígenas.A368727814927051600021780 +es_ESSGEL LIBROS SLzCALLE AV VALDEPARRA,29,.-28100 ALCOBENDAS - MADRID (ESPAñA) 998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de Productos9788435039963 +es_ES&Salvaje (Tapa dura) +es_ES&Salvaje (Tapa dura) +es_ES Jemmy Button es el más conocido de los indígenas de Patagonia que fueron trasladados a Inglaterra en las primeras décadas del siglo XIX con el propósito de estudiarlos y situarlos en la cadena evolutiva del hombre. Se convirtieron en poco menos que objetos de investigación científica, al tiempo que en atracción de feria. Button fue el que mostró una mayor capacidad de adaptación y el que mayores logros obtuvo en su aprendizaje de la lengua inglesa y las costumbres británicas, y por elo es también el más conocido, pero acabó sus días acusado de la muerte de toda la tripulación de una goleta.A través de su historia, Nick Hazlewood traza una imagen muy poco complaciente del darwinismo, de la frenología y sobre todo de la política de la Corona británica en Argentina, que acabó en una vorágine de exterminio de los indígenas. +calificacion1Acalificacion2Ecalificacion3E5calificacion4VVcalificacion5A06pler4twpwa2rdqpkcwmvhkxxd52gpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02014-10-30T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02014-10-31T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02004-11-30T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE6ONEa3a2qz2bn5caz6 ENTITY{"identifier":"Diciembre","name":[{"value":"Diciembre","locale":"es_ES"}],"external_identifier":"374789090","description":[{"value":"Diciembre","locale":"es_ES"}],"type_lookup":"1050"}MANYa3aauuktnvama2 ENTITY{"identifier":"0098956","name":[{"value":"NICK HAZLEWOOD","locale":"es_ES"}],"external_identifier":"434411051","given_name":"NICK","family_name":"HAZLEWOOD","birth_place":[],"death_place":[],"biography":[{"value":"Es licenciado en Historia y ha viajado a menudo por Centroamérica y América del Sur. Desde hace ya unos años, es periodista y escritor independiente, y ha publicado recientemente John Hawkyns, Elizabeth I and the Trafficking in Human Souls.","locale":"es_ES"}],"media_objects":[],"normalized_name":"nick-hazlewood"}ONEa3novp2ls57ixm STRING`[{"locale":"es_ES","value":"NOVELA HISTÓRICA"}]ONEa4m7lrwonaxq74 ENTITY{"identifier":"Inglés","name":[{"value":"Inglés","locale":"es_ES"}],"external_identifier":"347433090","description":[{"value":"Inglés","locale":"es_ES"}],"type_lookup":"157"}ONEa4pp5rqvfzxxf6 NUMBER23ONEa5ej6iwjweshes STRING000ONEa6vetl5kp4q3rc ENTITY{"identifier":"No Publicado","name":[{"value":"No Publicado","locale":"es_ES"}],"external_identifier":"351280090","description":[{"value":"No Publicado","locale":"es_ES"}],"type_lookup":"417"}ONEaawxj2frtynidc ENTITY{"identifier":"20101105033739","name":[{"value":"TIERRA INCÓGNITA","locale":"es_ES"}],"external_identifier":"590776053"}ONEabrulnhj2sxpbm ENTITY{"identifier":"Tapa dura","name":[{"value":"Tapa dura","locale":"es_ES"}],"external_identifier":"9651456090","description":[{"value":"Tapa dura","locale":"es_ES"}],"type_lookup":"420"}ONEacnblp3uq557wk STRING005ONEadwyeen33wnwra STRING001ONEahe5xxsrn42nyq STRINGh[{"locale":"es_ES","value":"Cavándoli, Margarita"}]ONEaitc57dwo6e7iqBOOLEANtrueONEaj6qadcmhrezii NUMBER468ONEajjkwpbdx2sews NUMBER720ONEamtwcchnrdjzfw ENTITY{"identifier":"g","name":[{"value":"g","locale":"es_ES"}],"external_identifier":"347187090","description":[{"value":"g","locale":"es_ES"}],"type_lookup":"206"}ONEangal4rqdmxpse STRINGR[{"locale":"es_ES","value":"LITERATURA"}]ONEaogwgan32v4m66 STRINGDSMANYaoyr2i73cpmiu6 ENTITY{"identifier":"Castellano","name":[{"value":"Castellano","locale":"es_ES"}],"external_identifier":"347423090","description":[{"value":"Castellano","locale":"es_ES"}],"type_lookup":"157"}ONEaps33pgkahzbpe NUMBER1ONEau4wikbtn4ylzk STRINGSalvajeMANYavavneorwb4aq4 ENTITY{"identifier":"Blanco y negro","name":[{"value":"Blanco y negro","locale":"es_ES"}],"external_identifier":"392072090","description":[{"value":"Blanco y negro","locale":"es_ES"}],"type_lookup":"1010"}ONEavl7kh42fi2dm4 NUMBER15MANYavmuqs346a7gxm ENTITY{"identifier":"Tapa dura","name":[{"value":"Tapa dura","locale":"es_ES"}],"external_identifier":"10121052090","description":[{"value":"Tapa dura","locale":"es_ES"}],"type_lookup":"418"}ONEawxedxihgayc72 NUMBER2004ONEay5m4egk42mrno ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}MANY*libros_iss_calculatedCOMPLEX{"name":"NICK HAZLEWOOD","rol":"Autor","grouper":"author","normalize_name_grouper":"author|nick-hazlewood"}Libros_ISS.SPEC_SECONDARY_TEMPLATEaños +es_ESaños 18.000años +es_ESaños999.000 +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000100764922"2004-11-30T23:00Z"2014-10-31T23:00Z"2014-10-30T23:00Z$001006520283711 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hc0dd2269-65bf-4fc4-8b6d-c7cdde4f89f7 DELETE<2023-09-02T17:25:21.848504165Z4dataloader-mongo-kafka-job62023-09-02T17:25:34.209692Z(mixer-gtin-agr-kfreeH5f01ceda-e5d6-4ee9-a7cd-a209d076598162023-09-02T17:25:37.432128Z,mixer-gtin-calc-pcsflmH19efabf0-4c98-417e-a254-af8d672676aa62023-09-02T17:25:46.428152Z,mixer-gtin-calc-pcsflmH04e4163e-fd59-4d54-8854-101a2284ed8c62023-09-03T02:47:15.540227Z0mixer-product-calc-kfreeH5a154881-23ba-4dc0-b08d-33384cc1ca3b<2024-01-19T11:18:46.203287038Z$mixer-xsell-mixtriH19b25244-6060-4b39-90b0-2d1d6a28d9b162024-01-19T11:18:46.272327Z4mixer-packing-units-mixtriH979d024f-26e9-4616-8b40-227a4d52e8c362024-01-19T11:18:46.833140Z.mixer-offer-badge-mixbiHe1370945-8430-47e6-8226-107d163c25ec62024-01-19T11:25:56.005217Z.mixer-offer-badge-mixbiH3884c64c-e888-4f9a-9380-39eb889dac79(7×cLoffer(A41172147).publish_ends_extendedIVA02IGIC91 +02085001054340279616001400COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001054340002085038&includeAsWebNovelty +es_ESNovedadDVD"2021-09-19T22:00Z8445110286920Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2021-09-21T14:36:52Z +es_ESTS_DAISY158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008445110286920$000001518573890038TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png2401811913479147145056DESIGUALmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/0/00001269350/00001269350419mM1011.jpg +es_ESDesigual +es_ESRopa997.41964062011 +es_ESRopa +5.000 +es_ESModa Mujer997.41875780011 +es_ESModa Mujer 32.000 +es_ES,Cross - Contenedor 8DO997.41837795011 +es_ESContenedor 8DOCDNN +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41172147 +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0022144 +es_ESABASIC, S.A. +es_EStCamiseta de mujer con mensaje de la colección y margarita +es_ESCamiseta con mensaje Treat people with kindness' es el importante mensaje de esta camiseta floral. Como detalle, los pespuntes overlock en en mangas y bajo. Confeccionada en algodón sostenible.A41172147147145056DESIGUAL +es_ESDESIGUAL15134011600022144 +es_ESABASIC, S.A.CALLE PASSEIG DEL MARE NOSTRUM,15-08039 BARCELONA - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize22SWTK61 +es_EStCamiseta de mujer con mensaje de la colección y margarita +es_EStCamiseta de mujer con mensaje de la colección y margarita +es_ESCamiseta con mensaje Treat people with kindness' es el importante mensaje de esta camiseta floral. Como detalle, los pespuntes overlock en en mangas y bajo. Confeccionada en algodón sostenible. calificacion1Acalificacion2Acalificacion3RIcalificacion4VVcalificacion5Bcalificacion62100N47927409038 +es_ES38E +es_ESEspañol479443090S +es_ESS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-21T03:07:57.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-22T03:07:57.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-02-03T05:04:53.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar en agua fría","name":[{"value":"Lavar en agua fría","locale":"es_ES"}],"external_identifier":"349555090","description":[{"value":"Lavar en agua fría","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado delicado","name":[{"value":"Planchado delicado","locale":"es_ES"}],"external_identifier":"351060090","description":[{"value":"Planchado delicado","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Planchado delicado","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201606/28/23309_1_.png","size":"small"}],"description":[{"value":"Planchado delicado","locale":"es_ES"}],"identifier":"23309","name":[{"value":"PLANCHADO_DELICADO","locale":"es_ES"}],"external_identifier":"12615474054"}} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":95,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":5,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518573890038(2022-02-03T05:04:53Z(2022-09-22T03:07:57Z(2022-09-21T03:07:57Z$001054340002085038001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore038Hdb3fec0e-2339-4244-9d06-07e2fb7f6edb DELETE<2023-09-02T17:25:37.713119329Z4dataloader-mongo-kafka-job62023-09-02T17:25:48.684123Z(mixer-gtin-agr-kfreeHcb5e2509-9e0a-4a43-846f-4e292e771ba162023-09-02T17:27:01.312629Z,mixer-gtin-calc-pcsflmH9976bafb-ed74-49ad-bcf2-ba26c9ef82d562023-09-02T17:27:02.213932Z,mixer-gtin-calc-pcsflmH9bc516cf-7353-487a-85fe-9e0e932eb64d62023-09-02T22:12:53.965736Z0mixer-product-calc-kfreeH32c8bd2d-0270-45a6-9d85-518739dc82b1<2024-01-19T11:17:57.502813350Z$mixer-xsell-mixtriHbdc09de7-e9ae-4ff4-94cb-d1d7620536d262024-01-19T11:17:57.548514Z4mixer-packing-units-mixtriH82c51347-5367-4803-bb46-74baa9adf79162024-01-19T11:18:47.027449Z.mixer-offer-badge-mixbiH93a8ef8f-fa07-4b3d-bf08-89b6f211a38362024-01-19T11:25:56.009180Z.mixer-offer-badge-mixbiH88e1e854-ce16-4096-9eaa-d01537786fd2(7×cIVA02IGIC91 +0939800102023-02-08T06:34:01.845Z011026857897001202COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001011020209398085&includeAsWebNovelty +es_ESNovedadDVD"2018-06-17T22:00Z4058509002090 +Rosas +es_ES +Rosas +Rosas +es_ES +Rosas Fucsia +es_ES Fucsia351544090 +es_ES Fucsia599655054 +50014 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___50014O3.png +es_ESCOLOR_FUCSIA +es_ESColor Fucsia Fucsia +es_ES Fucsia0(2018-09-06T12:00:56Z +es_ES*SUJETADOR DEPORTIVO A +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004058509002090$000001468160440085TRADICIONAL +es_ESCOLOR_FUCSIA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___50014O3.png24016859999758184550056 +ANITA +es_ES +Anita +es_ES,Sujetadores deportivos999.12677997013 +es_ES,Sujetadores deportivos +2.000 +es_ESSujetadores999.8512639013 +es_ESSujetadores +6.000 +es_ES2017 Lencería999.2685422013 +es_ESLencería +6.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ES,Sujetadores deportivos999.39105293013 +es_ES,Sujetadores deportivos +3.000 +es_ESAthleisure999.39105289013 +es_ESAthleisure 27.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ES>Sujetadores deportivos de mujer999.12687714013 +es_ES,Sujetadores deportivos +4.000 +es_ESRopa Deportiva999.8521227013 +es_ESAthleisure 47.000 +es_ES2017 Lencería999.2685422013 +es_ESLencería +6.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ES,Sujetadores deportivos999.39072742013 +es_ES,Sujetadores deportivos +2.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 11.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A269159934885331600063305 +es_ES"ANITA SPAIN, S.L.CALLE MARQUES DE PARADAS, 53.PLANTA,.-41001 SEVILLA - SEVILLA (ESPAñA)  +es_ESSujetador deportivo Active Anita tipo top sin aro con copa transpirable +es_ESSujetador Active tipo top sin aros, en color rosa fucsia, con copas de espuma transpirable. Pretina bajo el pecho, copa de doble capa, tirantes confort y corte ergonómico.A269159938184550056 +ANITA +es_ES +ANITA4885331600063305 +es_ES"ANITA SPAIN, S.L.CALLE MARQUES DE PARADAS, 53.PLANTA,.-41001 SEVILLA - SEVILLA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize +5544B +es_ESSujetador deportivo Active Anita tipo top sin aro con copa transpirable +es_ESSujetador deportivo Active Anita tipo top sin aro con copa transpirable +es_ESSujetador Active tipo top sin aros, en color rosa fucsia, con copas de espuma transpirable. Pretina bajo el pecho, copa de doble capa, tirantes confort y corte ergonómico. +calificacion1Acalificacion2Ecalificacion3RPcalificacion4VVcalificacion5NS00479098090100 +es_ES100E +es_ESEspañol479098090100 +es_ES100477062090Español +Talla479429090B +es_ESBE +es_ESEspañol479429090B +es_ESB477062090EspañolCopapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-08-29T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-08-30T22:00:00.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02018-09-03T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}{"identifier":"No centrifugar","name":[{"value":"No centrifugar","locale":"es_ES"}],"external_identifier":"347781090","description":[{"value":"No centrifugar","locale":"es_ES"}],"type_lookup":"1584"}MANYa3kybygykw5doe ENTITY{"identifier":"Deportivo","name":[{"value":"Deportivo","locale":"es_ES"}],"external_identifier":"5290003090","description":[{"value":"Deportivo","locale":"es_ES"}],"type_lookup":"2505"}MANYa4ljbqm5nabztw ENTITY{"identifier":"Continuidad","name":[{"value":"Continuidad","locale":"es_ES"}],"external_identifier":"2696215090","description":[{"value":"Continuidad","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Sujetadores deportivos","name":[{"value":"Sujetadores deportivos","locale":"es_ES"}],"external_identifier":"8970128090","description":[{"value":"Sujetadores deportivos","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYagio3trrjaqhgg ENTITY{"identifier":"Fibras sintéticas","name":[{"value":"Fibras sintéticas","locale":"es_ES"}],"external_identifier":"22937672090","description":[{"value":"Fibras sintéticas","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Ropa deportiva","name":[{"value":"Ropa deportiva","locale":"es_ES"}],"external_identifier":"392135090","description":[{"value":"Ropa deportiva","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Rosa","color_description":[{"value":"Rosa","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Rosa","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png","size":"small"}],"description":[{"value":"Rosa","locale":"es_ES"}],"identifier":"2019","name":[{"value":"COLOR_ROSA","locale":"es_ES"}],"external_identifier":"598506054"},"identifier":"Rosa","name":[{"value":"Rosa","locale":"es_ES"}],"external_identifier":"347700090"}MANYaj3ufdvuwowrlw ENTITY{"identifier":"Sin aro","name":[{"value":"Sin aro","locale":"es_ES"}],"external_identifier":"2696269090","description":[{"value":"Sin aro","locale":"es_ES"}],"type_lookup":"1601"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":49,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":39,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":12,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001468160440085"2018-09-03T22:00Z"2019-08-30T22:00Z"2019-08-29T22:00Z$001011020209398085001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore085H007aba5a-a82c-4cb7-8ad2-c887841b46fc DELETE<2023-09-02T17:10:41.090378083Z4dataloader-mongo-kafka-job62023-09-02T17:10:51.172166Z(mixer-gtin-agr-kfreeH7a0175d4-6382-412f-8761-0b38a10a45c962023-09-02T17:11:18.405037Z,mixer-gtin-calc-pcsflmH728900b8-4b4f-410e-ba82-32594a046ba662023-09-02T17:11:22.303071Z,mixer-gtin-calc-pcsflmHbe12ab4e-f4e5-4439-ad53-d0f649a34fc162023-09-03T02:24:56.195003Z0mixer-product-calc-kfreeHef44cce3-5be6-447b-b128-b866a340cb84<2024-01-19T11:17:43.094773116Z$mixer-xsell-mixtriH99322996-ce67-4e95-b966-9277af56c90d62024-01-19T11:17:57.686171Z4mixer-packing-units-mixtriH386526be-95f0-43af-bce2-6630d7610e8d62024-01-19T11:18:47.048564Z.mixer-offer-badge-mixbiH746929c9-98ff-461b-9e3c-c17399250a9662024-01-19T11:25:56.009911Z.mixer-offer-badge-mixbiH9bd24128-6294-4a0a-b015-f2a722b45cc3(7×cLoffer(A37928761).publish_ends_extendedIVA02IGIC91 +00069001058240669440001375COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001058237500069002&includeAsWebNovelty +es_ESNovedadDVD"2020-11-02T23:00Z8445164780399Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2021-11-10T16:21:41Z +es_ES*TOP TIRANTES VOLANTES158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008445164780399$000001506790230002TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png24017803506642307390056 +SFERAmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA01/201309/13/1377521437_1_.jpg +es_ES +Sfera +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A37928761 +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN5916991600910596 +es_ES$EVE LAYPER, S.A.U.CALLE DAZA VALDES(P.N.SRA.BUTARQUE),9-28914 LEGANES - MADRID (ESPAñA)  +es_ES*Top tirantes volantes +es_ESjTop de punto de tirantes con volantes. Algodón 100%.A379287612307390056 +SFERA +es_ES +SFERA5916991600910596 +es_ES$EVE LAYPER, S.A.U.CALLE DAZA VALDES(P.N.SRA.BUTARQUE),9-28914 LEGANES - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize1163505 +es_ES*Top tirantes volantes +es_ES*Top tirantes volantes +es_ESjTop de punto de tirantes con volantes. Algodón 100%. calificacion1CNcalificacion2CNcalificacion3RVcalificacion4VVcalificacion5ACcalificacion6K10047927409038 +es_ES38E +es_ESEspañol479443090S +es_ESS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-07-29T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-01T03:46:36.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-02-15T05:31:15.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEac5swxsdtmjapu ENTITY{"identifier":"Tops","name":[{"value":"Tops","locale":"es_ES"}],"external_identifier":"347931090","description":[{"value":"Tops","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Tirantes","name":[{"value":"Tirantes","locale":"es_ES"}],"external_identifier":"485212090","description":[{"value":"Tirantes","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas, Blusas y Tops","name":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"external_identifier":"2700640090","description":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001506790230002(2022-02-15T05:31:15Z(2022-08-01T03:46:36Z"2022-07-29T22:00Z$001058237500069002001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore002H29e39257-c7d9-4a36-8ec2-652679e3cbfb DELETE<2023-09-02T17:09:03.490486404Z4dataloader-mongo-kafka-job62023-09-02T17:09:11.789056Z(mixer-gtin-agr-kfreeH9d7ca3bd-7363-4c7a-acf3-c2296842350262023-09-02T17:09:17.517640Z,mixer-gtin-calc-pcsflmHa4a337d8-27db-46eb-acf5-f98bcd2d669a62023-09-02T17:09:27.425709Z,mixer-gtin-calc-pcsflmHae74b743-060e-4597-8d03-b7251f78552062023-09-02T21:44:38.648406Z0mixer-product-calc-kfreeH06b14b69-9951-4034-b03e-cc6f7dea0e32<2024-01-19T11:17:57.837943448Z$mixer-xsell-mixtriH8c0b0d50-9949-45d1-bffc-a11ec390a6b562024-01-19T11:17:58.033352Z4mixer-packing-units-mixtriH4f02b735-0c8d-457b-9aae-8d87272a80de62024-01-19T11:18:47.054709Z.mixer-offer-badge-mixbiHb0ee56bc-700b-4ff2-85f3-43901953430462024-01-19T11:25:56.010714Z.mixer-offer-badge-mixbiH4bdd5ab6-edc0-4961-8703-f4386b83ab35(7×cIVA02IGIC91 +0055200102023-02-14T03:19:25.031Z000237830893001359COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001000235900552118&includeAsWebNovelty +es_ESNovedadDVD Azules +es_ES Azules Azules +es_ES AzulesAzul claro +es_ESAzul claro347926090 +es_ESAzul Claro5994450544237 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___4237O2.png +es_ES COLOR_AZUL_CLARO +es_ES Color Azul ClaroAzul claro +es_ESAzul claro0(2021-01-13T09:14:21Z +es_ES(CAMISA ML CUELLO MAO +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401767717244$000001501768030118TRADICIONAL +es_ES COLOR_AZUL_CLARO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___4237O2.png2401767717244893929056FREESTYLEmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/0S/00/1/0000000S001/0000000S001463mM1011.jpg +es_ESFreestyle +es_ESCamisas999.39072597013 +es_ESCamisas +7.000 +es_ESBebé Niño999.39073122013 +es_ESBebé Niño +4.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN +es_ES`Moda_Infantil_ContenedorRebajaFinalTodo-60%_PV21997.39908319011 +es_ES`Moda_Infantil_ContenedorRebajaFinalTodo-60%_PV21N +es_ESCamisas999.2680877013 +es_ESCamisas 11.000 +es_ES0Bebé Niño (0-36 meses)999.2680836013 +es_ES0Bebé Niño (0-36 meses) +5.000 +es_ES2014 Infantil999.2680809013 +es_ESInfantil +3.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ESLModa_Infantil_Contenedor_DescuentosTop997.38744516011 +es_ESLModa_Infantil_Contenedor_DescuentosTopN*240176771723724017677172442401767717268240176771722024017677176952401767717688240176771771824017677177252401767717671240176904003624017690400292401769040050240176904004324017690523122401769052275240176905228224017690522442401769052268240176905229924017690523052401769052329A36118996A36119030A36285587A36286837 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A361189960900974 +es_ES SADHANA TEXTILES +es_ESHCamisa de bebé niño piqué celeste +es_ESCamisa manga larga algodón calidad piqué. Tiene cuello mao y cierre frontal con botones. +en_GBLong-sleeve piqué quality cotton shirt. Stand-up collar and front button fastening. +fr_FRChemise manches longues piqué de coton. Col mao et fermeture à boutons sur le devant.A36118996893929056FREE STYLE +es_ESFREE STYLE7418811600900974 +es_ES SADHANA TEXTILESCALLE SF NO.598,MUTHANAM PALAYAM RIN,86/1-641606 TIRUPUR - (INDIA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize12T4320 +es_ESHCamisa de bebé niño piqué celeste +es_ESHCamisa de bebé niño piqué celeste +es_ESCamisa manga larga algodón calidad piqué. Tiene cuello mao y cierre frontal con botones. +en_GBLong-sleeve piqué quality cotton shirt. Stand-up collar and front button fastening. +fr_FRChemise manches longues piqué de coton. Col mao et fermeture à boutons sur le devant. +calificacion1A1calificacion2Acalificacion3RPcalificacion4VVcalificacion5VV0047916209018 Meses +es_ES18 MesesE +es_ESEspañol19040858090 +12-18 +es_ES +12-1818171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-09-17T05:40:04.000ZONEafabpb3cbt6g3oTIMESTAMP02021-09-18T05:40:04.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-01-08T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Camisas","name":[{"value":"Camisas","locale":"es_ES"}],"external_identifier":"347642090","description":[{"value":"Camisas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Bebé Niño","name":[{"value":"Bebé Niño","locale":"es_ES"}],"external_identifier":"477515090","description":[{"value":"Bebé Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas","name":[{"value":"Camisas","locale":"es_ES"}],"external_identifier":"347767090","description":[{"value":"Camisas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001501768030118"2021-01-08T23:00Z(2021-09-18T05:40:04Z(2021-09-17T05:40:04Z$001000235900552118001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore118H4398a2cb-7989-40b5-8a69-b5e97d6260b1 DELETE<2023-09-02T17:13:44.561258780Z4dataloader-mongo-kafka-job62023-09-02T17:13:50.705165Z(mixer-gtin-agr-kfreeH5e7b0026-70b9-41c1-9705-bd7681a55b0e62023-09-02T17:13:52.922270Z,mixer-gtin-calc-pcsflmH8ce76bc3-6df8-4220-8b1a-a4b239ec788762023-09-02T17:13:58.125687Z,mixer-gtin-calc-pcsflmH43d0e41f-d785-453d-8115-36e91882e03a62023-09-03T02:29:19.779975Z0mixer-product-calc-kfreeH6396988a-ec88-47e2-8c02-1c4909249f73<2024-01-19T11:17:44.651434054Z$mixer-xsell-mixtriH9404ad03-744f-4f67-b9bc-cd5eb22b6ffe62024-01-19T11:17:57.763155Z4mixer-packing-units-mixtriHcad4f079-c463-4534-a001-eea747bf029b62024-01-19T11:18:47.233785Z.mixer-offer-badge-mixbiHf13a85bb-d344-48a6-903b-a1c08875843b62024-01-19T11:25:56.013342Z.mixer-offer-badge-mixbiH0d8d82ba-960d-42e4-9c5e-49f9048a85f8(7×cLoffer(A40136628).publish_ends_extendedIVA02IGIC92 +62382001002839972696001215COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001002821562382 &includeAsWebNovelty +es_ESNovedadDVD"2021-06-20T22:00Z8050597036762 Verdes +es_ES Verdes Verdes +es_ES VerdesVerde Agua +es_ESVerde Agua6186913090 +es_ESVerde agua15045844054 +13518 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201611/14/13518_1_.png +es_ESVERDE_AGUA +es_ESVerde aguaVerde Agua +es_ESVerde Agua0(2021-08-23T09:20:59Z +es_ES&FURLA SIRENA S HOBO158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008050597036762$000000000151494759TRADICIONAL +es_ESVERDE_AGUA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201611/14/13518_1_.png2401801861483191442056 +FURLA +es_ES +Furla +es_ES Bolsos de hombro999.39072325013 +es_ES Bolsos de hombro +2.000 +es_ES Bolsos999.39072321013 +es_ES Bolsos +3.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ES Bolsos999.39072321013 +es_ES Bolsos +3.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40136628 +es_ES Bolsos de hombro999.39072325013 +es_ES Bolsos de hombro +2.000 +es_ES Bolsos999.39072321013 +es_ES Bolsos +3.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0981860 +es_ESFURLA, SPA +es_ESxHobo Sirena S de piel en verde agua con bolsillos interiores +es_ESBolso de hombro tipo hobo de piel en color verde agua con cierre de broche mosquetón. Dispone de un asa media, asa larga y cuenta con tres bolsillos interiores, entre ellos uno de cremallera.A40136628191442056 +FURLA +es_ES +FURLA0981860 +es_ESFURLA, SPA998.00194 +es_ESComplementos998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosWB00355AX0733ME +es_ESxHobo Sirena S de piel en verde agua con bolsillos interioresWB00355AX0733ME +es_ESxHobo Sirena S de piel en verde agua con bolsillos interiores +es_ESBolso de hombro tipo hobo de piel en color verde agua con cierre de broche mosquetón. Dispone de un asa media, asa larga y cuenta con tres bolsillos interiores, entre ellos uno de cremallera. +calificacion1Acalificacion2Acalificacion3MTcalificacion4VVcalificacion5B06Npler4twpwa2rdqpeymj6wu3nmofgpaxawji3i4mkoqMANYa5wg3q7jlozdji ENTITY{"identifier":"Piel","name":[{"value":"Piel","locale":"es_ES"}],"external_identifier":"347595090","description":[{"value":"Piel","locale":"es_ES"}],"type_lookup":"1633"}ONEa5wuherdryc3vm NUMBER8.5MANYa5xfo2abga2eme NUMBER2021ONEa64wijst5hogcs ENTITY{"identifier":"Mosquetón","name":[{"value":"Mosquetón","locale":"es_ES"}],"external_identifier":"475283090","description":[{"value":"Mosquetón","locale":"es_ES"}],"type_lookup":"1574"}ONEaa72dm3yz6vb5u ENTITY{"identifier":"Bolsos de hombro","name":[{"value":"Bolsos de hombro","locale":"es_ES"}],"external_identifier":"2682108090","description":[{"value":"Bolsos de hombro","locale":"es_ES"}],"type_lookup":"1619"}ONEacu3nzdu3mtllm NUMBER25ONEacyfplvd6an7xo STRING[{"locale":"es_ES","value":"Liso"},{"locale":"pt_PT","value":"Liso"}]ONEafbexdxymegola ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}ONEamh4yuywyr3pna NUMBER24.5ONEangk62woh6lvtw STRING[{"locale":"es_ES","value":"Furla Sirena"},{"locale":"pt_PT","value":"Furla Sirena"}]ONEanxumtnaxc7bmw ENTITY{"identifier":"Bolsos","name":[{"value":"Bolsos","locale":"es_ES"}],"external_identifier":"344779090","description":[{"value":"Bolsos","locale":"es_ES"}],"type_lookup":"1573"}MANYarbqbgl5kiiqhmCOMPLEX +{"a3gd23j3lhtuz2":[{"a23xjq2h2haw5g":100.0,"a5shyljk4cvjq6":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"ajxlygljz2ct42":{"identifier":"Piel","name":[{"value":"Piel","locale":"es_ES"}],"external_identifier":"347595090","description":[{"value":"Pelle","locale":"it_IT"},{"value":"Leather","locale":"en_GB"},{"value":"Piel","locale":"es_ES"},{"value":"Cuir","locale":"fr_FR"},{"value":"Pele","locale":"pt_PT"}],"type_lookup":"1633"}}]}ONEasw5v2d7nudvia ENTITY{"identifier":"Media","name":[{"value":"Media","locale":"es_ES"}],"external_identifier":"472379090","description":[{"value":"Media","locale":"es_ES"}],"type_lookup":"1566"}MANYaz2gbwdmqlkyim ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYazrazbd5hx4qa4 ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"} Complementos_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-26T07:41:08.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-27T07:41:08.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-08-24T03:39:25.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000151494759(2021-08-24T03:39:25Z(2022-09-27T07:41:08Z(2022-09-26T07:41:08Z$001002821562382 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hd273a043-1c19-4665-8653-9b7d6ffa9156 DELETE<2023-09-02T17:27:27.984794270Z4dataloader-mongo-kafka-job62023-09-02T17:27:36.710178Z(mixer-gtin-agr-kfreeHd093fffa-3796-4a85-ad2a-36451e79dbf962023-09-02T17:30:26.311704Z,mixer-gtin-calc-pcsflmH1093b7f5-d3bd-4a14-a23c-622bd990987262023-09-02T17:30:34.503705Z,mixer-gtin-calc-pcsflmHa7c179f8-f2e7-4291-b0bb-e0bdf72e6c0d62023-09-02T22:09:23.170930Z0mixer-product-calc-kfreeHe56fcb29-9521-4d85-90ab-e641c9c0d577<2024-01-19T11:18:30.738492681Z$mixer-xsell-mixtriH38fc3fa4-9d11-406c-902e-338160f335b562024-01-19T11:18:30.846922Z4mixer-packing-units-mixtriHbd0d214d-1b44-483e-b173-090c821e8c1e62024-01-19T11:18:47.221205Z.mixer-offer-badge-mixbiH5c21da2b-3dc9-43e3-b6d6-b504e6d0e29562024-01-19T11:25:56.015434Z.mixer-offer-badge-mixbiHb26010b8-c78e-4c89-bc30-ca7d822e10ad(7×cLoffer(A40166549).publish_ends_extendedIVA02IGIC91 +00296001041540827059001204COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001041520400296005&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31820070090 +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31845113054 +32406 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png +es_ES&POLYESTER_RECICLADO +es_ES&Polyester reciclado +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png020 +es_ES&Polyester reciclado:SUSTAINABILITY_CLOSING_CIRCLENaranjas +es_ESNaranjasNaranjas +es_ESNaranjasMelocotón +es_ESMelocotón475609090 +es_ESMelocotón599739054 +51612 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___51612O1.png +es_ESCOLOR_MELOCOTON +es_ES Color MelocotónMelocotón +es_ESMelocotón0(2021-11-26T16:07:52Z +es_ES*ACOLCHADO.CORTO.CAPUC158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401802169090$000001515078080005TRADICIONAL +es_ESCOLOR_MELOCOTON +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___51612O1.png2401802169090124448056EASY WEARmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/1/00001269351/00001269351363mM1011.jpg +es_ESEasy Wear +es_ESPlumíferos999.39089882013 +es_ESPlumíferos +5.000 +es_ESAbrigos999.39072580013 +es_ESAbrigos 13.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ESRopa997.41964062011 +es_ESRopa +5.000 +es_ESModa Mujer997.41875780011 +es_ESModa Mujer 32.000 +es_ES6Cross - Contenedor 8DO pv22997.41837795011 +es_ES&Contenedor 8DO pv22CDNN +es_ESRopa997.38159713011 +es_ESRopa +2.000 +es_ESModa Mujer997.38150773011 +es_ESModa Mujer +5.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40166549 +es_ESPlumíferos999.39089882013 +es_ESPlumíferos +5.000 +es_ESAbrigos999.39072580013 +es_ESAbrigos 13.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0905094 +es_ESAICTEX LIMITED +es_ESJPlumífero de mujer corto con capucha +es_ESPlumífero corto con capucha y cierre frontal con cremallera. Tiene dos bolsillos en lateral con cremallera.A40166549124448056EASY WEAR +es_ESEASY WEAR12424121600905094 +es_ESAICTEX LIMITEDnCALLE MONG KOK ROAD,93-9-999077 KOWLOON - (HONG KONG) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize 204-17 +es_ESJPlumífero de mujer corto con capucha +es_ESJPlumífero de mujer corto con capucha +es_ESPlumífero corto con capucha y cierre frontal con cremallera. Tiene dos bolsillos en lateral con cremallera. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AD00N479307090 +40-42 +es_ES +40-42E +es_ESEspañol479437090L +es_ESL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-30T00:57:13.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-01T00:57:13.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-12-16T04:57:17.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar en centros especializados","name":[{"value":"Lavar en centros especializados","locale":"es_ES"}],"external_identifier":"347670090","description":[{"value":"Lavar en centros especializados","locale":"es_ES"}],"type_lookup":"1584"}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEabf2vvifj26pzi ENTITY{"identifier":"Corto","name":[{"value":"Corto","locale":"es_ES"}],"external_identifier":"2655626090","description":[{"value":"Corto","locale":"es_ES"}],"type_lookup":"2507"}ONEac5swxsdtmjapu ENTITY{"identifier":"Plumíferos","name":[{"value":"Plumíferos","locale":"es_ES"}],"external_identifier":"2682027090","description":[{"value":"Plumíferos","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Abrigos","name":[{"value":"Abrigos","locale":"es_ES"}],"external_identifier":"2700610090","description":[{"value":"Abrigos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX {"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster reciclado","name":[{"value":"Poliéster reciclado","locale":"es_ES"}],"external_identifier":"391093090","description":[{"value":"Poliestere riciclato","locale":"it_IT"},{"value":"Recycled polyester","locale":"en_GB"},{"value":"Poliéster reciclado","locale":"es_ES"},{"value":"Polyester recyclé","locale":"fr_FR"},{"value":"Poliéster reciclado","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001515078080005(2021-12-16T04:57:17Z(2022-10-01T00:57:13Z(2022-09-30T00:57:13Z$001041520400296005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H10703aad-c79e-4c08-b586-984246c1a69e DELETE<2023-09-02T17:30:02.879640975Z4dataloader-mongo-kafka-job62023-09-02T17:32:05.620508Z(mixer-gtin-agr-kfreeH44607e89-f111-47fa-b831-88d2670eddf862023-09-02T17:35:38.698613Z,mixer-gtin-calc-pcsflmH21a1eff1-5ca3-4537-bff5-85e2e593b8fc62023-09-02T17:35:52.449181Z,mixer-gtin-calc-pcsflmHe3f76b4b-75dc-41ec-8b5f-dd8904ca8dc062023-09-03T02:59:11.082324Z0mixer-product-calc-kfreeHc1228c75-11e9-46a1-b37a-9f6d85f72085<2024-01-19T11:18:31.268227545Z$mixer-xsell-mixtriH80854dcb-65c4-4d64-9bc7-a4fd03b74e1e62024-01-19T11:18:31.312045Z4mixer-packing-units-mixtriH6bc58141-a319-4c82-95a5-90c881633e3762024-01-19T11:18:47.230529Z.mixer-offer-badge-mixbiH581c466d-281a-421d-a671-47662e9c27e862024-01-19T11:25:56.087301Z.mixer-offer-badge-mixbiH036b060a-78ba-4da0-8146-22f96d3049b3(7×c,7ǻmf!Loffer(A40380011).publish_ends_extendedIVA02IGIC91 +03142001025441152573001201COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001025420103142004&includeAsWebNovelty +es_ESNovedadDVD +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2021-12-30T13:06:02Z +es_ES$BLUS ESTAMP VICHY158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401804364585$000001515753440004TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401804364585173428056COUCHEL +es_ESCouchel +es_ES,Camisas, Blusas y Tops999.39106219013 +es_ES,Camisas, Blusas y Tops +4.000 +es_ESTallas Grandes999.39106209013 +es_ESTallas Grandes +8.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESRopa997.38159713011 +es_ESRopa +2.000 +es_ESModa Mujer997.38150773011 +es_ESModa Mujer +5.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40380011 +es_ES,Camisas, Blusas y Tops999.39106219013 +es_ES,Camisas, Blusas y Tops +4.000 +es_ESTallas Grandes999.39106209013 +es_ESTallas Grandes +8.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0904836 +es_ES6ACHIEVER APPARELS PVT. LTD. +es_ESReacondicionados - Electrónica999.19641834013 +es_ES Reacondicionados 97.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNNN56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A46756381 +es_ES Sonido999.19641841013 +es_ES Sonido +2.000 +es_ESDReacondicionados - Imagen y Sonido999.19641839013 +es_ESTV y Sonido +2.000 +es_ES>Reacondicionados - Electrónica999.19641834013 +es_ES Reacondicionados 97.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNNN5330781600649707 +es_ESHPANASONIC ESPAÑA SUC. P.MARK.EURP.GCALLE PZ DE LA PAU,S-N(ED 8)PL,BJ-08940 CORNELLA DE LLOBREGAT - BARCELONA (ESPAñA)  +es_ESAuricular de botón Panasonic RZ-B100WDE-W True Wireless Bluetooth (Reacondicionado casi a estrenar) +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.4Embalaje poco deteriorado.Auricular de botón Panasonic RZ-B100WDE-W True Wireless BluetoothPanasonic presenta sus nuevos auriculares totalmente inalámbricos, de elegante diseño con estuche de carga que cabe en cualquier bolsillo. Estos pequeños auriculares combinan perfectamente con cualquier outfitGracias a la reconocida calidad de sonido de Panasonic, los auriculares B100 te permiten disfrutar de tu música y llamadas sin límites; con hasta 4 horas de reproducción y 16 horas de carga en el estuche. Es decir, con una sala carga podrás disfrutar hasta 4 ciclos de reproducción.Su nuevo diseño está pensando en la comodidad incluso para las orejas más sensibles, sin bloquearte del mundo exterior. También, gracias a sus comandos táctiles, podrás aceptar llamadas, pausar música y mucho más con un solo toque. Incluyen control por voz que es compatible con Siri y Google Assistant.No tendrás que preocuparte por usar tus auriculares mientras haces ejercicio o mientras llueve, ya que gracias a su certificación IPX4 estarás siempre protegido de salpicaduras.A46756381125364056PANASONIC +es_ESPANASONIC5330781600649707 +es_ES^PANASONIC ESPAÑA SUC. P.MARK.EURP.G_recargaNFTCALLE PZ DE LA PAU,S-N(ED 8)PL,BJ-08940 CORNELLA DE LLOBREGAT - BARCELONA (ESPAñA) 998.00012 +es_ESAuriculares998.00118 +es_ESElectrónica998 +es_ES@Jerarquía de Ficha de Productos +años +es_ES +años +3.000EL163RZ-B100WDE +es_ESAuricular de botón Panasonic RZ-B100WDE-W True Wireless Bluetooth (Reacondicionado casi a estrenar) +es_ESAuricular de botón Panasonic RZ-B100WDE-W True Wireless Bluetooth (Reacondicionado casi a estrenar) +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.4Embalaje poco deteriorado.Auricular de botón Panasonic RZ-B100WDE-W True Wireless BluetoothPanasonic presenta sus nuevos auriculares totalmente inalámbricos, de elegante diseño con estuche de carga que cabe en cualquier bolsillo. Estos pequeños auriculares combinan perfectamente con cualquier outfitGracias a la reconocida calidad de sonido de Panasonic, los auriculares B100 te permiten disfrutar de tu música y llamadas sin límites; con hasta 4 horas de reproducción y 16 horas de carga en el estuche. Es decir, con una sala carga podrás disfrutar hasta 4 ciclos de reproducción.Su nuevo diseño está pensando en la comodidad incluso para las orejas más sensibles, sin bloquearte del mundo exterior. También, gracias a sus comandos táctiles, podrás aceptar llamadas, pausar música y mucho más con un solo toque. Incluyen control por voz que es compatible con Siri y Google Assistant.No tendrás que preocuparte por usar tus auriculares mientras haces ejercicio o mientras llueve, ya que gracias a su certificación IPX4 estarás siempre protegido de salpicaduras. calificacion1C1calificacion2Acalificacion3E5calificacion4VVcalificacion5EScalificacion6WW00Npler4twpwa2rdqpby5czbf5ajadmMANYa3xlfkswyfjj24 ENTITY{"identifier":"USB","name":[{"value":"USB","locale":"es_ES"}],"external_identifier":"347408090","description":[{"value":"USB","locale":"es_ES"}],"type_lookup":"185","glossary":{"term":[{"value":"USB (Universal Serial Bus)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Puerto que permite conectar periféricos como una llave USB, un lector MP3, una cámara de fotos digital, etc. El USB 3.0 es la nueva versión ultrarrápida del interfaz USB. Norma para un nuevo bus (o comunicación) externo compatible con velocidades de transferencia de datos de 12 Mbps. Se prevé que USB sustituya completamente los puertos en serie y paralelo. Adicionalmente, USB resulta especialmente adecuado para la descarga directa a alta velocidad de imágenes, tan pronto como se realiza la conexión, entre una cámara digital y un ordenador.","locale":"es_ES"}],"identifier":"10415","name":[{"value":"USB_(UNIVERSAL_SERIAL_BUS)","locale":"es_ES"}],"external_identifier":"596787054"}}MANYa7y3l3kadfzggi ENTITY{"identifier":"Smartphone","name":[{"value":"Smartphone","locale":"es_ES"}],"external_identifier":"353945090","description":[{"value":"Smartphone","locale":"es_ES"}],"type_lookup":"28"}{"identifier":"Smart Watch","name":[{"value":"Smart Watch","locale":"es_ES"}],"external_identifier":"38602802090","description":[{"value":"Smart Watch","locale":"es_ES"}],"type_lookup":"28"}{"identifier":"Wearable","name":[{"value":"Wearable","locale":"es_ES"}],"external_identifier":"38602801090","description":[{"value":"Wearable","locale":"es_ES"}],"type_lookup":"28"}ONEad3cp2gof6q23u NUMBER0.23ONEafmripz4cmv3pc NUMBER +160.0ONEaimpmg7fhxogps NUMBER60.0ONEaitpugcxa7tmz4 NUMBER +110.0ONEalp3pc7gfphlhe ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}ONEaohjqp4ifinucs ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaq2iwf7rbyexzm ENTITY{"identifier":"Bluetooth 5.0","name":[{"value":"Bluetooth 5.0","locale":"es_ES"}],"external_identifier":"18423528090","description":[{"value":"Bluetooth 5.0","locale":"es_ES"}],"type_lookup":"185"}ONEatmduqvnbeog2i ENTITY{"identifier":"Botón","name":[{"value":"Botón","locale":"es_ES"}],"external_identifier":"354302090","description":[{"value":"Botón","locale":"es_ES"}],"type_lookup":"182"}ONEaznepd24xebzeu ENTITY{"identifier":"Universal","name":[{"value":"Universal","locale":"es_ES"}],"external_identifier":"354179090","description":[{"value":"Universal","locale":"es_ES"}],"type_lookup":"23"}Auriculares_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02023-01-31T08:13:58.000ZONEapruxddhqugapwBOOLEANtrueONEate3liesiuooycBOOLEANtrueMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}ONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEakzd7vzeui6lmu STRINGPONEazravcn5thdy6eTIMESTAMP02023-01-31T08:13:58.000ZONEafabpb3cbt6g3oTIMESTAMP02023-02-25T06:46:37.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000154194748DVD(2023-02-25T06:46:37Z(2023-01-31T08:13:58Z +es_ESCasi a estrenar32681225090Casi a estrenar +es_ESCasi a estrenar2643090$001054738512877 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H442d9c92-bde9-4d36-a29e-7a662cc19912 DELETE<2023-09-02T18:44:10.465653536Z4dataloader-mongo-kafka-job62023-09-02T18:58:01.710168Z(mixer-gtin-agr-kfreeH3a2f8bb1-0506-4ef5-bb83-9b1a8c3cec9f62023-09-02T20:26:50.819330Z,mixer-gtin-calc-pcsflmH3ddc5db3-c1d2-4e58-b0c3-42df849808fe62023-09-02T20:26:58.215696Z,mixer-gtin-calc-pcsflmH98036cb3-df09-4305-94ee-bdd5b302aefe62023-09-03T02:10:00.654147Z0mixer-product-calc-kfreeH5b9efd0c-a6b2-4fe7-90a2-f15435bd8a3f<2024-01-19T11:17:58.386575627Z$mixer-xsell-mixtriH53b36525-f790-4d56-a1ca-464825d6dedf62024-01-19T11:17:58.575544Z4mixer-packing-units-mixtriH9e0c9b7e-6e35-4882-921a-4e981b49f06f62024-01-19T11:18:47.416775Z.mixer-offer-badge-mixbiH0fd02efe-113a-418f-8ef4-6dae3d752d6b62024-01-19T11:25:56.096357Z.mixer-offer-badge-mixbiHde804eb1-daae-4f51-8138-ff262e5e0731(7×cIVA02IGIC92 +4710900102023-02-22T11:10:17.268Z013514632070001170COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001013517047109 &includeAsWebNovelty +es_ESNovedadDVD"2015-11-04T23:00Z2135170471096"2015-11-04T23:00Z3380810024388 +Rosas +es_ES +Rosas +Rosas +es_ES +Rosas1"2015-10-01T11:00Z +es_ESPERF.ESPECIAL +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003380810024388$000000000141284213MUESTRARIO +es_ES26 +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201610/21/00113517047109____2__225x225.jpg2401980359481169799056CLARINSmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/45/82/2/00001345822/00001345822946mM1011.jpg +es_ESClarins +es_ES2Incentivo MIMO maquillaje997.44216691011 +es_ES2Incentivo MIMO maquillaje 75.000 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta Perfumería997.25804492011 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta PerfumeríaCDN +es_ES*Cupon padre10 belleza997.41811881011 +es_ES*Cupon padre10 belleza 68.000 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta Perfumería997.25804492011 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta PerfumeríaCDN +es_ES Alta Perfumería997.38841159011 +es_ES Alta Perfumería +7.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESCupon verano 10997.42630624011 +es_ESCupon verano 10 72.000 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta Perfumería997.25804492011 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta PerfumeríaCDN +es_ES&mimo adelanto black997.44305573011 +es_ES&mimo adelanto black 76.000 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta Perfumería997.25804492011 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta PerfumeríaCDN +es_ES Alta Perfumería997.40416668011 +es_ES Alta Perfumería +4.000 +es_ES:Cross - Contenedor 8DO OI2122997.40414433011 +es_ES*Contenedor 8DO OI2122CDN +es_ES"Cyber Monday 2022997.44484000011 +es_ES"Cyber Monday 2022 77.000 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta Perfumería997.25804492011 +es_ESBelleza - Repositorio Perfumeria General Parafarmacia y Alta PerfumeríaCDN +es_ESAlta perfumeria997.44305575011 +es_ESAlta perfumeria +5.000 +es_ESXCross - Contenedor 2022 BF Resto categorías997.44305668011 +es_ES(BF Resto categoríasCDN +es_ESAlta Perfumeria997.44465037011 +es_ESAlta Perfumeria 20.000 +es_ESHCross - Contenedor 2022 Cyber Monday997.44305671011 +es_ESContenedor CMCDN +es_ES Alta perfumería997.41961663011 +es_ES Alta perfumería +3.000 +es_ES4Perfumería y parafarmacia997.41870018011 +es_ES4Perfumería y parafarmacia +9.000 +es_ES,Cross - Contenedor 8DO997.41837795011 +es_ESContenedor 8DOCDNN +es_ES41.3.3.1.- Barras de Labios999.12002216013 +es_ES Barras de Labios +1.000 +es_ES1.3.3.- Labios999.12001792013 +es_ES Labios +3.000 +es_ES 1.3.- Maquillaje999.12001641013 +es_ESMaquillaje 24.000 +es_ES0Perfumería y Cosmética999.51568013 +es_ESPerfumeríaNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A171631355824041600157388 +es_ESFCOMIT COM.ITALIANA ALIMENTACION, S.CALLE CL PEREZ GALDOS S-N - SAN ISID,.-38611 GRANADILLA DE ABONA - STA. CRUZ DE TENERIFE (ESPAñA)  +es_ESZ Barra de labios Joli Rouge Brillant Clarins +es_ESJoli Rouge Brillant asocia un color con total transparencia y el brillo de un gloss con la textura untuosa de una barra de labios, para unos labios golosos con un brillo exquisito y un color sublime.8Color con acabado brillante.(Modo de aplicación:@Aplicar como tu barra de labios.A17163135169799056CLARINS +es_ESCLARINS5824041600157388 +es_ESFCOMIT COM.ITALIANA ALIMENTACION, S.CALLE CL PEREZ GALDOS S-N - SAN ISID,.-38611 GRANADILLA DE ABONA - STA. CRUZ DE TENERIFE (ESPAñA) 998.00217 +es_ESBelleza998.00216 +es_ESPerfumeria998 +es_ES@Jerarquía de Ficha de Productos +color80005139 +es_ESZ Barra de labios Joli Rouge Brillant Clarins +es_ESZ Barra de labios Joli Rouge Brillant Clarins +es_ESJoli Rouge Brillant asocia un color con total transparencia y el brillo de un gloss con la textura untuosa de una barra de labios, para unos labios golosos con un brillo exquisito y un color sublime.8Color con acabado brillante.(Modo de aplicación:@Aplicar como tu barra de labios. calificacion1Acalificacion2Icalificacion3N5calificacion4VVcalificacion5Bcalificacion6CG00 3,5 gr +es_ES 3,5 gr349417090"Belleza - Tamañodefaultpffaizwzp2c5jwpler4twpwa2rdqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02019-04-18T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02019-04-19T22:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02016-10-19T09:56:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa2npzl2kbbfl5o STRING26ONEa33s65hw3elmxg ENTITY{"identifier":"Suave","name":[{"value":"Suave","locale":"es_ES"}],"external_identifier":"235309090","description":[{"value":"Suave","locale":"es_ES"}],"type_lookup":"10117"}ONEa46n6dsokiuyoi ENTITY{"identifier":"Barras de labios","name":[{"value":"Barras de labios","locale":"es_ES"}],"external_identifier":"12544871090","description":[{"value":"Barras de labios","locale":"es_ES"}],"type_lookup":"10118"}MANYa72ajtlhcrmcew ENTITY{"identifier":"Rosas","name":[{"value":"Rosas","locale":"es_ES"}],"external_identifier":"235326090","description":[{"value":"Rosas","locale":"es_ES"}],"type_lookup":"10115"}ONEak6mkpuv26dkpc ENTITY{"identifier":"Maquillaje","name":[{"value":"Maquillaje","locale":"es_ES"}],"external_identifier":"238926090","description":[{"value":"Maquillaje","locale":"es_ES"}],"type_lookup":"10119"}ONEaowsxs4xvhekaa ENTITY{"identifier":"26","name":[{"value":"26","locale":"es_ES"}],"external_identifier":"235758090","description":[{"value":"26","locale":"es_ES"}],"type_lookup":"10128"}MANYaufrgwd5i3v3dq STRING@Aplicar como tu barra de labios.MANYawwmxxkdwijgkc ENTITY{"identifier":"Femenino","name":[{"value":"Femenino","locale":"es_ES"}],"external_identifier":"201926090","description":[{"value":"Femenino","locale":"es_ES"}],"type_lookup":"10112"}ONEazf3ov7ixmhdkw ENTITY{"identifier":"1379684468","name":[{"value":"Joli Rouge","locale":"es_ES"}],"external_identifier":"2385007058"}Perfumeria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000141284213"2016-10-19T09:56Z(2019-04-19T22:00:01Z(2019-04-18T22:00:01Z$001013517047109 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H1f3d6d5f-5b39-4892-ad8f-0ad6fa52551f DELETE<2023-09-02T17:16:33.336588580Z4dataloader-mongo-kafka-job62023-09-02T17:16:40.676531Z(mixer-gtin-agr-kfreeHe7ea2983-3251-42fe-bd3c-a4cd4df94d1562023-09-02T17:16:42.308309Z,mixer-gtin-calc-pcsflmH3c304213-262d-428c-80f1-b2cbd875b6fc62023-09-02T17:16:45.603818Z,mixer-gtin-calc-pcsflmHa4f160db-c746-458f-bd0f-9e96e4ca30f262023-09-02T21:46:08.971648Z0mixer-product-calc-kfreeH9a109c8c-2fdd-46e6-b1ab-f84e10d86674<2024-01-19T11:17:58.007042527Z$mixer-xsell-mixtriH09ddebce-e8ac-466f-8e10-ac59279fb0a062024-01-19T11:17:58.141997Z4mixer-packing-units-mixtriH3875690a-c0de-46cd-9056-63d305e62df262024-01-19T11:18:47.418083Z.mixer-offer-badge-mixbiHda5fe57a-cee3-4d05-acda-dff5f5c4042e62024-01-19T11:25:56.097025Z.mixer-offer-badge-mixbiH7c79d4ca-45c9-4572-894d-f2659af0e2e1(7×cLoffer(A35055131).publish_ends_extendedIVA02IGIC91 +00580001087234468096001600VALDEMORO +es_ESVALDEMOROCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001087260000580038"2020-03-01T23:00Z3603527847430 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2020-03-02T17:27:26Z +es_ES JERSEY158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003603527847430$000001498433360038TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401759906618123333056 KOOKAI +es_ES Kookai +es_ESRopa mujer997.44306143011 +es_ESRopa mujer +1.000 +es_ESXCross - Contenedor 2022 Black Friday Moda 40997.44305666011 +es_ES(Black Friday Moda 40CDN +es_ES Punto y Jerséis999.39090705013 +es_ES Punto y Jerséis 15.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A35055131 +es_ES Punto y Jerséis999.39090705013 +es_ES Punto y Jerséis 15.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN6204111600491621 +es_ES&KOOKAI IBERIA, S.L.CALLE D POL. IND. PONT XETMAR,S/N-17844 CORNELLA DEL TERRI - GIRONA (ESPAñA)  +es_ESFJersey de mujer ajustado de canalé +es_ESJersey de punto en canalé, con mangas largas y cuello redondo, un básico perfecto para tu armario esta temporada, combinable con la mayoría de tus looks. La modelo lleva la talla 36 y mide 1,76m.A35055131123333056 KOOKAI +es_ES KOOKAI6204111600491621 +es_ESSudadera de mujer Floral adidas +en_GBSport isn't just about the wins, the miles or the medals, it's a personal journey that comes down to feeling your very best. Celebrate your own growth and resilience in this adidas hoodie. Soft cotton fabric feels luxurious against the skin, while a floral print on the front blooms as bright as your inner confidence. By buying cotton products from us, you're supporting more sustainable cotton farming. +es_ESEl deporte no se trata solo de las victorias, las millas o las medallas, es un viaje personal que se reduce a sentirse lo mejor posible. Celebre su propio crecimiento y resistencia con esta sudadera con capucha de adidas. La tela de algodón suave se siente lujosa contra la piel, mientras que un estampado floral en el frente florece tan brillante como tu confianza interior. Al comprarnos productos de algodón, está apoyando un cultivo de algodón más sostenible.A39817806123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize GT8818 +es_ES>Sudadera de mujer Floral adidas +es_ES>Sudadera de mujer Floral adidas +en_GBSport isn't just about the wins, the miles or the medals, it's a personal journey that comes down to feeling your very best. Celebrate your own growth and resilience in this adidas hoodie. Soft cotton fabric feels luxurious against the skin, while a floral print on the front blooms as bright as your inner confidence. By buying cotton products from us, you're supporting more sustainable cotton farming. +es_ESEl deporte no se trata solo de las victorias, las millas o las medallas, es un viaje personal que se reduce a sentirse lo mejor posible. Celebre su propio crecimiento y resistencia con esta sudadera con capucha de adidas. La tela de algodón suave se siente lujosa contra la piel, mientras que un estampado floral en el frente florece tan brillante como tu confianza interior. Al comprarnos productos de algodón, está apoyando un cultivo de algodón más sostenible. calificacion1Acalificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO06N479448090XS +es_ESXSE +es_ESEspañol479448090XS +es_ESXS477062090Españolpler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-10-06T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-11-30T07:43:00.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-06-05T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"347714090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"485392090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1599"}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001513664590036"2021-06-05T22:00ZDVD"2021-11-30T07:43Z"2021-10-06T22:00Z$001032417906784036001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore036H4e925b45-36a7-4954-b6ab-d5a0c6c58fc7 DELETE<2023-09-02T17:36:36.001326316Z4dataloader-mongo-kafka-job62023-09-02T17:48:54.636160Z(mixer-gtin-agr-kfreeHbedf7a13-2a2a-4dd9-92cb-fa44a79f332362023-09-02T17:49:57.019199Z,mixer-gtin-calc-pcsflmHc97a9ca8-d794-48ee-b45d-47e4f4783c1862023-09-02T17:49:58.825566Z,mixer-gtin-calc-pcsflmH309f3ef7-c213-40fc-8912-2131346a5ae862023-09-02T22:40:11.766967Z0mixer-product-calc-kfreeHd8286efe-8f35-4aee-8cf0-ffbbbbea1cdf<2024-01-19T11:18:47.108817830Z$mixer-xsell-mixtriH1801d4eb-5cb6-4d16-9b16-ea727ea9879a62024-01-19T11:18:47.235215Z4mixer-packing-units-mixtriHec8f8b7d-bda5-45ab-bc8c-2fd1e991870062024-01-19T11:18:47.445620Z.mixer-offer-badge-mixbiH0ed8ac6a-1d1f-4f67-a7d6-5417461e9aad62024-01-19T11:25:56.099657Z.mixer-offer-badge-mixbiH37a0e175-6332-4180-ae5e-8c23ade201a2(7×cLoffer(A40281222).publish_ends_extendedIVA02IGIC91 +05295001029540499257001131COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001029513105295004&includeAsWebNovelty +es_ESNovedadDVD +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN Azules +es_ES Azules Azules +es_ES AzulesAzul índigo +es_ESAzul índigo2693194090 +es_ESAzul Índigo26566293054 +12744 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/14/12744_1_.png +es_ES"COLOR_AZUL_INDIGO +es_ES$Color Azul ÍndigoAzul índigo +es_ESAzul índigo0(2021-10-25T14:49:05Z +es_ESCAMISA ML RAYAS158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401803358943$000001515441700004TRADICIONAL +es_ES"COLOR_AZUL_INDIGO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/14/12744_1_.png2401803358943130248056GREEN COASTmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/1/00001269351/00001269351384mM1011.jpg +es_ESGreen Coast +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESRopa997.38159713011 +es_ESRopa +2.000 +es_ESModa Mujer997.38150773011 +es_ESModa Mujer +5.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40281222 +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN5925041600923805 +es_ES(CANNON HYGIENE, S.A.CALLE MAR MEDITERRANEO,1-28830 SAN FERNANDO DE HENARES - MADRID (ESPAñA)  +es_ES&Blusa rayas botones +es_ESBlusa de manga larga con botón en el puño, cierre de botones en el cuerpo y estampado de rayas. Es una blusa ligera y versátil confeccionada en tejido de 100% algodón. Es la blusa perfecta para darle un toque de color a todos tus looks.BModelo: 174 de altura y talla 036A40281222130248056GREEN COAST +es_ESGREEN COAST5925041600923805 +es_ES(CANNON HYGIENE, S.A.CALLE MAR MEDITERRANEO,1-28830 SAN FERNANDO DE HENARES - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeGC22VT06 +es_ES&Blusa rayas botones +es_ES&Blusa rayas botones9999999.000 +es_ESBlusa de manga larga con botón en el puño, cierre de botones en el cuerpo y estampado de rayas. Es una blusa ligera y versátil confeccionada en tejido de 100% algodón. Es la blusa perfecta para darle un toque de color a todos tus looks.BModelo: 174 de altura y talla 036 calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5ADcalificacion6DE00N479439090M +es_ESME +es_ESEspañol479439090M +es_ESM477062090Español +Talla peohixr7rbw25wpz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqpzemnwoecgod3uONEadxazarzusz3teBOOLEAN +falseONEatos7dqm35n3ma NUMBER9999999Comunes_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-30T00:53:34.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-01T00:53:34.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-12-15T03:41:12.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Rayas","name":[{"value":"Rayas","locale":"es_ES"}],"external_identifier":"2655617090","description":[{"value":"Rayas","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Blusas","name":[{"value":"Blusas","locale":"es_ES"}],"external_identifier":"2682030090","description":[{"value":"Blusas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYagio3trrjaqhgg ENTITY{"identifier":"100% Algodón","name":[{"value":"100% Algodón","locale":"es_ES"}],"external_identifier":"32382944090","description":[{"value":"100% Algodón","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas, Blusas y Tops","name":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"external_identifier":"2700640090","description":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"adbyfb4jfvuv5k":100.0,"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2021ONEaumavohvmjmvoo ENTITY{"identifier":"CM18","name":[{"value":"CM18","locale":"es_ES"}],"external_identifier":"42180479090","description":[{"value":"Utopía","locale":"es_ES"}],"type_lookup":"2667090"}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001515441700004(2021-12-15T03:41:12Z(2022-10-01T00:53:34Z(2022-09-30T00:53:34Z$001029513105295004001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore004Heebbab4f-4e65-4b0b-8988-dfcbb9671248 DELETE<2023-09-02T17:27:48.550643657Z4dataloader-mongo-kafka-job62023-09-02T17:27:54.797913Z(mixer-gtin-agr-kfreeHd7c8fc3b-51af-4b6d-8c71-296087b4d43662023-09-02T17:28:12.716142Z,mixer-gtin-calc-pcsflmH6312c630-3816-4928-8b51-40d87c79e3cd62023-09-02T17:28:13.819640Z,mixer-gtin-calc-pcsflmH13e4e3bf-3083-4789-a891-c7707fb09a7262023-09-02T22:14:56.762569Z0mixer-product-calc-kfreeH57b281b6-f953-4eaa-9ba8-1fcedaae838f<2024-01-19T11:17:59.396503162Z$mixer-xsell-mixtriH023a422c-709b-4ce9-b984-d754d8b0aed462024-01-19T11:17:59.634808Z4mixer-packing-units-mixtriHeef91957-cd06-43c1-b6b7-adc5c72f332462024-01-19T11:18:47.538273Z.mixer-offer-badge-mixbiHa14ed3af-7263-42e4-951d-0e46e299009f02024-01-19T11:25:56.102Z.mixer-offer-badge-mixbiH6c557381-93b0-4463-8c4d-9d6df30f9061(7×c,7ǻmf! Loffer(A41757626).publish_ends_extendedIVA02IGIC91 +31265001024942100545001550COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001024955031265005 +es_ESInternet1229735090Internet +es_ESInternet(2023-01-24T04:57:47ZDVD"2021-11-18T23:00Z3616533914027Multicolor +es_ESMulticolorMulticolor +es_ESMulticolorMulticolor +es_ESMulticolor352633090 +es_ESMulticolor598507054 +20205 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png +es_ES6COLOR_MULTICOLOR_SECUNDARIO +es_ES6Color Multicolor SecundarioMulticolor +es_ESMulticolor0(2022-04-05T13:07:12Z +es_ES*CAMISETAS M/CORTA VER155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003616533914027$000001521501630005TRADICIONAL +es_ES6COLOR_MULTICOLOR_SECUNDARIO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png2401817589289132250056"POLO RALPH LAURENmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/81/51/3/00001281513/00001281513473mM1011.jpg +es_ES"Polo Ralph Lauren +es_ES"Hombre y Equipaje997.38864709011 +es_ES"Hombre y Equipaje +9.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESCamisetas999.39072569013 +es_ESCamisetas 10.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41757626 +es_ESCamisetas999.39072569013 +es_ESCamisetas 10.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN4867851600046193 +es_ES8RALPH LAUREN ESPAÑA, S.L.U.vCALLE CL SERRANO,26-3º,..-28001 MADRID - MADRID (ESPAñA)  +es_ESJCamiseta de hombre algodón degradado +es_ESEsta camiseta en suave punto jersey de algodón se ha confeccionado con un proceso tie-dye en varios niveles e incorpora detalles hechos a mano que convierten cada pieza en una prenda única.A41757626132250056RALPH LAUREN +es_ESRALPH LAUREN4867851600046193 +es_ES8RALPH LAUREN ESPAÑA, S.L.U.vCALLE CL SERRANO,26-3º,..-28001 MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize710860407001 +es_ESJCamiseta de hombre algodón degradado +es_ESJCamiseta de hombre algodón degradado +es_ESEsta camiseta en suave punto jersey de algodón se ha confeccionado con un proceso tie-dye en varios niveles e incorpora detalles hechos a mano que convierten cada pieza en una prenda única. +calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5Z100N4793600905 +es_ES5E +es_ESEspañol479445090XL +es_ESXL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa2ynyjkfoo2woqTIMESTAMP02098-12-31T23:00:01.000ZONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"010","name":[{"value":"010","locale":"es_ES"}],"external_identifier":"233767090","description":[{"value":"Gestión Automática - Publica despublicadas con stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02018-12-31T23:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-06T22:00:01.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-04-07T05:42:25.000ZONEate3liesiuooycBOOLEAN +falseMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}MANYaqundqcyqbyf5mTIMESTAMP02023-01-24T04:57:47.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar a máquina","name":[{"value":"Lavar a máquina","locale":"es_ES"}],"external_identifier":"392860090","description":[{"value":"Lavar a máquina","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","name":[{"value":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","locale":"es_ES"}],"external_identifier":"10460407090","description":[{"value":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","locale":"es_ES"}],"type_lookup":"1584"}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Fantasía","name":[{"value":"Fantasía","locale":"es_ES"}],"external_identifier":"25521449090","description":[{"value":"Fantasía","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Redondo","name":[{"value":"Redondo","locale":"es_ES"}],"external_identifier":"485162090","description":[{"value":"Redondo","locale":"es_ES"}],"type_lookup":"1595"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Sport","name":[{"value":"Sport","locale":"es_ES"}],"external_identifier":"347623090","description":[{"value":"Sport","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":100.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001521501630005(2022-04-07T05:42:25Z(2022-09-06T22:00:01Z(2018-12-31T23:00:01Z$001024955031265005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005Hc8ce7793-6076-42a9-9362-0ec1d02ee046 DELETE<2023-09-02T17:19:33.955052187Z4dataloader-mongo-kafka-job62023-09-02T17:19:43.478540Z(mixer-gtin-agr-kfreeH318f0396-9819-45e2-8c4a-7ad2eb3149ad62023-09-02T17:20:01.902794Z,mixer-gtin-calc-pcsflmHeffbbe39-4e59-4b06-bd1e-4073dbf0d79f62023-09-02T17:20:08.514620Z,mixer-gtin-calc-pcsflmH446bdb8c-1a74-47f9-9324-f0d324d0dd1262023-09-03T02:35:57.501342Z0mixer-product-calc-kfreeH0b0709ab-9e84-4e9e-9601-5189be6bc210<2024-01-19T11:18:32.060889042Z$mixer-xsell-mixtriH60565855-b178-44f9-86c3-4155e026de2f62024-01-19T11:18:32.124912Z4mixer-packing-units-mixtriH9bbeaed3-fbd9-48a9-bc6a-1143f82f45e962024-01-19T11:18:47.640793Z.mixer-offer-badge-mixbiH9a1bfbfd-efcd-4576-b3e6-12df38299c7c62024-01-19T11:25:56.104476Z.mixer-offer-badge-mixbiHb5e1bebd-e697-4443-8614-21530fd4390b(7×cLoffer(A42582323).publish_ends_extendedIVA02IGIC91 +00313001029341501763001909COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001029390900313002&includeAsWebNovelty +es_ESNovedadDVD"2022-01-25T23:00Z5057847661470 Verdes +es_ES Verdes Verdes +es_ES VerdesVerde claro +es_ESVerde claro348270090 +es_ESVerde Claro598439054 +15726 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___15726O1.png +es_ES"COLOR_VERDE_CLARO +es_ES"Color Verde ClaroVerde claro +es_ESVerde claro0(2022-02-02T13:09:25Z +es_ESBAÑADORES158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005057847661470$000001524966410002TRADICIONAL +es_ES"COLOR_VERDE_CLARO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___15726O1.png24018263610983160085056SUPERDRY +es_ESSuperdry +es_ES Bragas de bikini999.39089969013 +es_ES Bragas de bikini +3.000 +es_ESBikinis999.39089965013 +es_ESBikinis +8.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42582323 +es_ES Bragas de bikini999.39089969013 +es_ES Bragas de bikini +3.000 +es_ESBikinis999.39089965013 +es_ESBikinis +8.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0903616 +es_ESVBO GRANT THORNTON EFFICIENTIA DKH RETAILLTD +es_ES.Braga de bikini Hipster +es_ES Esta braguita de bikini ha sido especialmente diseñada para que puedas presumir de estilo deportivo allá donde vayas. Decorada con emblemáticos logotipos de la marca, se trata de una apuesta verdaderamente infalible. Corte ceñido: un corte entallado, que se ciñe al cuerpo. Diseño de braguita clásico. Forro completo. Cinturilla elástica con el logotipo de la marca grabado. Con top de bikini a juego disponible. Nota: por motivos de higiene, no aceptamos cambios o devoluciones de los bañadores a menos que estén sellados en su envase original. Esto no afecta a tus derechos establecidos por ley.A425823233160085056SUPERDRY +es_ESSUPERDRY10593731600903616 +es_ESVBO GRANT THORNTON EFFICIENTIA DKH RETAILLTD`CALLE RUE SIMONIS,53-1050 BRUSSELS - (BELGICA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeW3010270A +es_ES.Braga de bikini Hipster +es_ES.Braga de bikini Hipster +es_ES Esta braguita de bikini ha sido especialmente diseñada para que puedas presumir de estilo deportivo allá donde vayas. Decorada con emblemáticos logotipos de la marca, se trata de una apuesta verdaderamente infalible. Corte ceñido: un corte entallado, que se ciñe al cuerpo. Diseño de braguita clásico. Forro completo. Cinturilla elástica con el logotipo de la marca grabado. Con top de bikini a juego disponible. Nota: por motivos de higiene, no aceptamos cambios o devoluciones de los bañadores a menos que estén sellados en su envase original. Esto no afecta a tus derechos establecidos por ley. calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5Bcalificacion612PDN47925309036 +es_ES36E +es_ESEspañol47909509010 +es_ES1018171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-30T04:18:05.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-04-27T04:19:21.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar máximo 30º C","name":[{"value":"Lavar máximo 30º C","locale":"es_ES"}],"external_identifier":"21449008090","description":[{"value":"Lavar máximo 30º C","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}{"identifier":"No planchar","name":[{"value":"No planchar","locale":"es_ES"}],"external_identifier":"350554090","description":[{"value":"No planchar","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No Planchar","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___840O1.png","size":"small"}],"description":[{"value":"No Planchar","locale":"es_ES"}],"identifier":"840","name":[{"value":"NO_PLANCHAR","locale":"es_ES"}],"external_identifier":"600047054"}} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Flores","name":[{"value":"Flores","locale":"es_ES"}],"external_identifier":"9338924090","description":[{"value":"Flores","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bragas de bikini","name":[{"value":"Bragas de bikini","locale":"es_ES"}],"external_identifier":"12873128090","description":[{"value":"Bragas de bikini","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Bikinis","name":[{"value":"Bikinis","locale":"es_ES"}],"external_identifier":"8970133090","description":[{"value":"Bikinis","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":17,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":93,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster reciclado","name":[{"value":"Poliéster reciclado","locale":"es_ES"}],"external_identifier":"391093090","description":[{"value":"Poliestere riciclato","locale":"it_IT"},{"value":"Recycled polyester","locale":"en_GB"},{"value":"Poliéster reciclado","locale":"es_ES"},{"value":"Polyester recyclé","locale":"fr_FR"},{"value":"Poliéster reciclado","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001524966410002(2022-04-27T04:19:21Z(2022-09-30T04:18:05Z(2022-08-15T22:00:01Z$001029390900313002001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore002Hf1f6b3a4-a646-4544-8e6e-cd9dee62fb17 DELETE<2023-09-02T17:29:41.788750669Z4dataloader-mongo-kafka-job62023-09-02T17:30:19.281285Z(mixer-gtin-agr-kfreeH95b9457d-c60a-42c7-b7ce-b3bd440335c662023-09-02T17:35:52.603211Z,mixer-gtin-calc-pcsflmH8f569ad8-40eb-4133-a15d-48f3890bfea062023-09-02T17:36:04.006396Z,mixer-gtin-calc-pcsflmH1882ecf5-f438-441a-9e7c-2fc006ed329562023-09-03T02:50:34.929569Z0mixer-product-calc-kfreeH1019a102-a6fb-4401-9daa-98a5d7590a69<2024-01-19T11:18:31.995685557Z$mixer-xsell-mixtriH42da1d0b-45a3-4a2b-becf-d6b2ee0d123062024-01-19T11:18:32.078890Z4mixer-packing-units-mixtriHe17176fa-7f34-4de1-b31c-4aa332bffd8762024-01-19T11:18:47.646975Z.mixer-offer-badge-mixbiH0c9b4f63-809e-4caf-bfce-8035ff29ae1d62024-01-19T11:25:56.105209Z.mixer-offer-badge-mixbiH7c378ad8-2127-4659-bf45-02ec9c3bcc19(7×cLoffer(A40509698).publish_ends_extendedIVA02IGIC91 +01291001041540897103001154COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001041515401291005&includeAsWebNovelty +es_ESNovedadDVD +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa +es_ESRosa347700090 +es_ESRosa5985060542019 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png +es_ESCOLOR_ROSA +es_ESColor RosaRosa +es_ESRosa0(2021-12-03T15:07:14Z +es_ES*PANTALON FELPA CULOTT158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401805658263$000001516204820005TRADICIONAL +es_ESCOLOR_ROSA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png2401805658263124448056EASY WEARmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/1/00001269351/00001269351363mM1011.jpg +es_ESEasy Wear +es_ES$Pantalones culotte999.39090694013 +es_ES$Pantalones culotte +3.000 +es_ESPantalones999.39090691013 +es_ESPantalones 20.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ESLoungewear999.39090783013 +es_ESLoungewear 29.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40509698 +es_ES$Pantalones culotte999.39090694013 +es_ES$Pantalones culotte +3.000 +es_ESPantalones999.39090691013 +es_ESPantalones 20.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN5915061600907659 +es_ES>BERTOLIN GARCIA, GABRIEL CARLOSAVENIDA PEREZ GALDOS, 103 - PTA.34,.-46018 VALENCIA - VALENCIA (ESPAñA)  +es_ES\Pantalón culotte de mujer con goma en cintura +es_ESPantalón culotte liso con goma y cordón en cintura. Tiene dos bolsillos.A40509698124448056EASY WEAR +es_ESEASY WEAR5915061600907659 +es_ES>BERTOLIN GARCIA, GABRIEL CARLOSAVENIDA PEREZ GALDOS, 103 - PTA.34,.-46018 VALENCIA - VALENCIA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeS22-1002-P +es_ES\Pantalón culotte de mujer con goma en cintura +es_ES\Pantalón culotte de mujer con goma en cintura +es_ESPantalón culotte liso con goma y cordón en cintura. Tiene dos bolsillos. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AD00N479307090 +40-42 +es_ES +40-42E +es_ESEspañol479437090L +es_ESL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-19T02:50:31.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-20T02:50:31.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-01-23T03:55:18.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pantalones culotte","name":[{"value":"Pantalones culotte","locale":"es_ES"}],"external_identifier":"32382953090","description":[{"value":"Pantalones culotte","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":60.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":40.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001516204820005(2022-01-23T03:55:18Z(2022-09-20T02:50:31Z(2022-09-19T02:50:31Z$001041515401291005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H6ea4ba7f-3cf9-40e0-af58-6afa6be48879 DELETE<2023-09-02T17:24:40.459061375Z4dataloader-mongo-kafka-job62023-09-02T17:24:49.198401Z(mixer-gtin-agr-kfreeHf0c598fc-ce2b-413e-87aa-20e42eea440662023-09-02T17:25:01.245421Z,mixer-gtin-calc-pcsflmH6046157f-5a8c-4827-aa69-266450afc32b62023-09-02T17:25:02.610640Z,mixer-gtin-calc-pcsflmH111c236b-472b-4e68-bd86-13e06176978162023-09-03T02:51:11.551127Z0mixer-product-calc-kfreeH04c72000-75c7-4f96-b909-ef5eef5fbd36<2024-01-19T11:18:32.202738703Z$mixer-xsell-mixtriH5d63b468-187c-4d2b-8f3e-f9645f8355fb62024-01-19T11:18:32.292567Z4mixer-packing-units-mixtriH0e2604b4-fe91-4ce0-a64e-aa49983d849062024-01-19T11:18:47.710630Z.mixer-offer-badge-mixbiHb6a1fb62-2aa3-45e9-9349-c220a7851a4a62024-01-19T11:25:56.106092Z.mixer-offer-badge-mixbiHe3b958a7-f220-45a0-bc57-c5c20454f36a(7×cLoffer(A46919017).publish_ends_extendedIVA02IGIC91 +00206001086545387093001116(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001086511600206002"2023-01-31T23:00Z5056661316023 Verdes +es_ES Verdes Verdes +es_ES Verdes +Verde +es_ES +Verde347197090 +es_ES +Verde597003054 +11929 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___11929O2.png +es_ESCOLOR_VERDE +es_ESColor Verde +Verde +es_ES +Verde0(2023-02-02T13:05:18Z +es_ES ALBUS TROUSERS K156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005056661316023$000001542541640002TRADICIONAL +es_ESCOLOR_VERDE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___11929O2.png240187118489545387801056 +AMAIA +es_ES +Amaia +es_ESPantalones999.39089855013 +es_ESPantalones +2.000 +es_ESPantalones999.39089850013 +es_ESPantalones +6.000 +es_ESBebé Niño999.39073122013 +es_ESBebé Niño +4.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A46919017 +es_ESPantalones999.39089855013 +es_ESPantalones +2.000 +es_ESPantalones999.39089850013 +es_ESPantalones +6.000 +es_ESBebé Niño999.39073122013 +es_ESBebé Niño +4.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN0024896 +es_ES Albus Trousers K +es_ES"Albus Trousers K.Hecho en EspanaA4691901745387801056 +AMAIA +es_ES +AMAIA16960121600024896 +es_ESBAMAIA KIDS SPAIN, S.L._recargaNFTCALLE LEOPOLDO CALVO-SOTELO BUS,46-28224 POZUELO DE ALARCON - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeALBUSTRK +es_ES Albus Trousers K +es_ES Albus Trousers K +es_ES"Albus Trousers K.Hecho en Espana +calificacion1Acalificacion2Acalificacion3M1calificacion4VVcalificacion5VV00N4791770902 Años +es_ES2 AñosE +es_ESEspañol4791770902 Años +es_ES2 Años477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02023-01-30T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02023-01-31T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Admite planchado","name":[{"value":"Admite planchado","locale":"es_ES"}],"external_identifier":"8955929090","description":[{"value":"Admite planchado","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Centrifugado suave","name":[{"value":"Centrifugado suave","locale":"es_ES"}],"external_identifier":"484873090","description":[{"value":"Centrifugado suave","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347622090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Bebé Niño","name":[{"value":"Bebé Niño","locale":"es_ES"}],"external_identifier":"477515090","description":[{"value":"Bebé Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"adbyfb4jfvuv5k":100.0,"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"},{"value":"Algodão","locale":"pt_PT"},{"value":"Coton","locale":"fr_FR"},{"value":"Cotton","locale":"en_GB"},{"value":"Cotone","locale":"it_IT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2023Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001542541640002DVD"2023-01-31T23:00Z"2023-01-30T23:00Z$001086511600206002001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore00208H992e518f-07b4-45bc-8057-d7c19d1dd7c7 DELETE<2023-09-02T17:48:38.129263409Z4dataloader-mongo-kafka-job62023-09-02T18:08:15.724649Z(mixer-gtin-agr-kfreeHf259b55e-a7fa-4091-979b-eff1c22f293a62023-09-02T18:08:38.816385Z,mixer-gtin-calc-pcsflmHc2608330-b2ec-4402-b252-34124ee7316962023-09-02T18:08:40.231586Z,mixer-gtin-calc-pcsflmH4025f105-1490-4650-bbeb-bfabe38a686462023-09-02T22:47:37.666739Z0mixer-product-calc-kfreeHa3dda61a-84b0-4e3b-99da-8a18ed1bf89d<2024-01-19T11:18:32.333814453Z$mixer-xsell-mixtriH095074c4-4857-4d72-9b19-4e30de54112d62024-01-19T11:18:32.465942Z4mixer-packing-units-mixtriH9c683df0-45d0-4051-b0b8-77ccee17412762024-01-19T11:18:47.714527Z.mixer-offer-badge-mixbiH6c50121b-d747-46f3-8158-655005c6b8cd62024-01-19T11:25:56.106692Z.mixer-offer-badge-mixbiHdeb2751a-b226-4661-85cb-1ba2f89af563(7×cLoffer(A31279758).publish_ends_extendedIVA02IGIC91 +03584001099430455719001475COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001099447503584012&includeAsWebNovelty +es_ESNovedadDVD"2018-06-21T22:00Z0820652018815 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2019-01-04T12:22:08Z +es_ES*B NK DRY ACDMY DRIL T26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000820652018815$000001468481420012TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401686668313123744056NIKEmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201407/29/1248768132_2_.jpg +es_ESNike +es_ESSudaderas999.14731212013 +es_ESSudaderas +3.000 +es_ESRopa deportiva999.14566788013 +es_ESRopa deportiva +1.000 +es_ES Niños999.12406167013 +es_ES Niños +4.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES Niños999.17528231013 +es_ES Niños +3.000 +es_ESEquipaciones999.53785013 +es_ESEquipaciones +4.000 +es_ESFútbol999.53778013 +es_ESFútbol 19.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESTDeportes - Contenedor Deportes 2as Rebajas997.39518311011 +es_ES>Contenedor Deportes 2as RebajasN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN0192499652027A35860764A35861011A29069177A3825239026 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A31279758 +es_ESSudaderas999.14731212013 +es_ESSudaderas +3.000 +es_ESRopa deportiva999.14566788013 +es_ESRopa deportiva +1.000 +es_ES Niños999.12406167013 +es_ES Niños +4.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN0998229 +es_ESPNIKE EUROPEAN OPERATION NETHERLANDS B.V. +es_ESNSudadera de niños Dri-Fit Academy Nike +es_ES4Calidez donde Tú quieras. La sudadera Nike Dri-FIT Academy está confeccionada con una tecnología con capilarización del sudor para mantener la transpirabilidad y la comodidad. Las aberturas invisibles para los pulgares mantienen la sujeción de las mangas. Tecnología Dri-FIT para ofrecerle comodidad sin humedad, y ayudar a mantener la concentración. Tejido del cuerpo cepillado para una mayor calidez y comodidad. Las mangas raglán se adaptan fácilmente a tus movimientos. Las aberturas invisibles para los pulgares permanecen ocultas cuando no se usan. La cremallera de 1/4 te permite ajustar la ventilación. El diseño del logotipo Swoosh está bordado. +en_GB0Warmth wherever you wantThe Nike Dri-FIT Academy Top is made with sweat-wicking technology to help keep you dry and comfortable. Invisible Thumb Loops keep your sleeves secured.A31279758123744056NIKE +es_ESNIKE0998229 +es_ESPNIKE EUROPEAN OPERATION NETHERLANDS B.V.998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeAO0738-451 +es_ESNSudadera de niños Dri-Fit Academy Nike +es_ESNSudadera de niños Dri-Fit Academy Nike +es_ESTradicional233777090Tradicional +es_ESTradicional +101079999999.000 +es_ES4Calidez donde Tú quieras. La sudadera Nike Dri-FIT Academy está confeccionada con una tecnología con capilarización del sudor para mantener la transpirabilidad y la comodidad. Las aberturas invisibles para los pulgares mantienen la sujeción de las mangas. Tecnología Dri-FIT para ofrecerle comodidad sin humedad, y ayudar a mantener la concentración. Tejido del cuerpo cepillado para una mayor calidez y comodidad. Las mangas raglán se adaptan fácilmente a tus movimientos. Las aberturas invisibles para los pulgares permanecen ocultas cuando no se usan. La cremallera de 1/4 te permite ajustar la ventilación. El diseño del logotipo Swoosh está bordado. +en_GB0Warmth wherever you wantThe Nike Dri-FIT Academy Top is made with sweat-wicking technology to help keep you dry and comfortable. Invisible Thumb Loops keep your sleeves secured. calificacion1A7calificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO0647911009012 Años +es_ES12 AñosE +es_ESEspañol47911009012 Años +es_ES12 Años477062090Español +Talla peohixr7rbw25wpler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqpzemnwoecgod3uONEadxazarzusz3teBOOLEAN +falseONEatos7dqm35n3ma NUMBER9999999Comunes_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-07-14T00:42:03.000ZONEafabpb3cbt6g3oTIMESTAMP02022-07-15T00:42:03.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02019-09-16T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Niños","name":[{"value":"Niños","locale":"es_ES"}],"external_identifier":"349990090","description":[{"value":"Niños","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"347714090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"485392090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2019Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001468481420012"2019-09-16T22:00Z(2022-07-15T00:42:03Z(2022-07-14T00:42:03Z$001099447503584012001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore012Hfcaacb78-9008-40f3-ba44-688a0f0d8532 DELETE<2023-09-02T17:03:48.924806640Z4dataloader-mongo-kafka-job62023-09-02T17:03:58.805098Z(mixer-gtin-agr-kfreeH963567f5-ad26-4591-81f7-56d93f9a06de62023-09-02T17:04:22.913202Z,mixer-gtin-calc-pcsflmHa0c8c33c-9b03-4828-98ec-bdc165957a8262023-09-02T17:04:27.801968Z,mixer-gtin-calc-pcsflmH5747894c-928f-4996-9985-15f35439775662023-09-03T02:48:21.878789Z0mixer-product-calc-kfreeHbcc1da23-bcf3-494d-a3a0-d1d926914170<2024-01-19T11:18:47.124155987Z$mixer-xsell-mixtriHe79e10b5-a4fb-415b-9845-0cd0246de96d62024-01-19T11:18:47.262025Z4mixer-packing-units-mixtriHe4aa602d-32f4-4853-baca-b81819c7873962024-01-19T11:18:47.947118Z.mixer-offer-badge-mixbiH521b956f-fa5f-4cae-8c08-e3262b3e834a62024-01-19T11:25:56.112879Z.mixer-offer-badge-mixbiH69968b3a-264f-4690-b0d8-cafccbc6e677(7×cLoffer(A36489166).publish_ends_extendedIVA02IGIC92(2022-01-16T08:19:52Z +11201001A012833463565001005VPR +es_ESVPRCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001012800511201 "2020-01-08T23:00Z2128005112011 Grises +es_ES Grises Grises +es_ES Grises&Monet / Gris oscuro +es_ES&Monet / Gris oscuro34255615090&Monet / Gris oscuro +es_ES&Monet / Gris oscuro1(2020-01-10T10:40:56Z +es_ESSOFA 2PL27 +es_ESVPR274981090VPR395ML +es_ESml +0.0002401753465814$000000000149594219MUESTRARIO +es_ES&Monet / Gris oscuro +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202010/09/00112800511201____5__225x225.jpg2401753465814123707056EL CORTE INGLES +es_ES El Corte Inglés +es_ES0Sofás tapizados_NO VALE999.12743202013 +es_ES Sofás tapizados +9.000 +es_ESFSofás Salón Comedor - NO UTILIZAR999.52968013 +es_ES Sofás +6.000 +es_ESMuebles999.52958013 +es_ESMuebles +5.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNNN +es_ES(Personaliza tu sofá999.35882987013 +es_ES(Personaliza tu sofá +1.000 +es_ES.Sofás_nueva jerarquía999.35882986013 +es_ES Sofás +6.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN +es_ES$Sofás de 2 plazas999.36491522013 +es_ES$Sofás de 2 plazas +7.000 +es_ES.Sofás_nueva jerarquía999.35882986013 +es_ES Sofás +6.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN 240175344439024017534507282401753445557240175348255224017534906492401753445267240175345475724017534564232401753481555240175344244024017534485892401753443539240175349105924017534525482401753483887240175345456624017534763392401753470689240175348361024017534926292401753453798240175347945324017534627212401753489186240175344430724017534733832401753480220240175346723824017534542762401753471440240175344507624017534569972401753478296240175345408524017534828732401753466460240175347167924017534571852401753480091240175344898524017534606042401753452258240175346512824017534562322401753478579240175348683324017534859422401753472720240175346617024017534532172401753479668240175347243024017534837952401753455235240175348798424017534704982401753483344240175346243124017534597832401753471860240175348537924017534793612401753491417240175348845524017534886152401753461274240175345359024017534722492401753489759240175347801224017534589222401753485065240175345024724017534520672401753453026240175345690424017534818072401753451015240175346531924017534840682401753464459240175348066424017534688602401753446134240175344766724017534674292401753481395240175346569224017534535072401753482699240175349173824017534797672401753480503240175347040524017534775412401753470870240175348344324017534621412401753479910240175346007924017534731092401753446899240175345177024017534816852401753448794240175344214324017534904892401753455532240175348107424017534861092401753449753240175346069724017534425702401753469737240175348886824017534849692401753490908240175348578224017534500492401753467719240175348637624017534448882401753446325240175349122624017534900452401753471068240175348740324017534843342401753469928240175346185424017534894452401753477350240175348626024017534739562401753458342240175348478524017534935102401753447377240175344785824017534592192401753477824240175348699424017534933502401753490328240175344401724017534549482401753487878240175348521824017534646402401753487113240175345120624017534580522401753467900240175349303924017534781042401753473574240175348553924017534737652401753466941240175348756424017534720582401753478456240175347770124017534866732401753445847240175347692624017534767422401753460987240175346368124017534846002401753446615240175345661424017534468062401753467993240175349198124017534512992401753483160240175346675024017534787602401753489919240175345572324017534527392401753480947240175347656824017534772512401753469157240175342045524017534887142401753468570240175346301824017534641692401753487724240175348451824017534790642401753491837240175346560924017534895992401753442860240175348196824017534482442401753471259240175348082424017534803432401753477060240175348566924017534824462401753470214240175348932224017534658832401753490175240175345950924017534881342401753476469240175349246924017534890252401753443058240175345959224017534438292401753444598240175347915624017534842042401753449562240175348724324017534821252401753492308240175346156424017534633912401753449173240175348123424017534577652401753460284240175345747524017534788522401753472911240175346483124017534505372401753492148240175349076224017534433482401753469447240175345594524017534822862401753492735240175349157824017534639712401753493190240175348829524017534515892401753463308240175348301624017534731922401753492872240175349364024017534471862401753458632240175346828024017534850962401753489926240175346465724017534679172401753457192240175347041224017534450832401753461571240175349174524017534884622401753468297240175348010724017534471932401753460994240175349080924017534803672401753461861240175344258724017534612812401753451503240175344585424017534667672401753485706240175347187724017534928962401753465135240175349277324017534733902401753452074240175346618724017534727372401753476766240175348083124017534445052401753444802240175347358124017534828972401753484792240175347937824017534827052401753483177240175348156224017534424642401753450063240175349033524017534901822401753453705240175347736724017534805102401753448909240175344556424017534731162401753478869240175344383624017534540922401753481975240175345255524017534777492401753483351240175346008624017534580692401753473307240175347916324017534677262401753488158240175345595224017534468132401753444895240175347088724017534491802401753481401240175349185124017534627382401753478586240175346743624017534583592401753445274240175347635324017534624482401753470696240175346029124017534775582401753446622240175348305424017534653262401753465807240175344899224017534720652401753448251240175348800424017534609012401753466958240175348903224017534510222401753483801240175347726824017534821322401753452265240175348960524017534853862401753420462240175345476424017534571092401753468204240175345922624017534714572401753463025240175347802924017534840752401753472447240175347126624017534883012401753489469240175344614124017534769712401753487151240175347978124017534812412401753447865240175349008324017534875712401753473963240175345073524017534897662401753482590240175345691124017534920012401753450544240175346360524017534921552401753466477240175346417624017534606112401753484624240175347022124017534787772401753487007240175348390024017534555492401753454573240175348229324017534672452401753470603240175348887524017534862772401753442150240175347907124017534878922401753489193240175348726724017534633152401753490656240175347647624017534691642401753444314240175347168624017534597902401753464466240175344976024017534783022401753447100240175347812824017534549552401753449579240175348434124017534836272401753448701240175348497624017534864132401753493206240175349263624017534845252401753471075240175349231524017534818212401753443065240175348872124017534535142401753442877240175348580524017534855462401753451787240175349336724017534904962401753451596240175348098524017534722562401753453033240175346561624017534574822401753477077240175349158524017534799272401753481722240175345322424017534810982401753462158240175349368824017534778312401753490922240175349304624017534552422401753493527240175348773124017534562492401753459707240175348595924017534866802401753463988240175349123324017534502542401753482453240175346945424017534910802401753469935240175347967524017534794602401753485225240175344767424017534540092401753486840240175348424224017534577722401753447384240175345428324017534784942401753444024240175345121324017534658902401753456430240175346369824017534806712401753464848240175346887724017534765752401753472928240175349142424017534886222401753443546240175348026824017534527462401753458939240175345951624017534874102401753443355240175345573024017534834672401753456621240175346974424017534737722401753486116240175348935324017534924762401753446332240175346858724017534586492401753486451240175345693524017534507592401753479392240175344356024017534589532401753476643240175348437224017534691882401753461885240175348572024017534669722401753464480240175346419024017534926502401753483207240175346001724017534890562401753471006240175349160824017534804352401753477862240175344452924017534710992401753461502240175347024524017534547882401753482637240175345741324017534781802401753485157240175346611824017534823162401753482736240175344433824017534815862401753471280240175347313024017534923392401753454023240175348054124017534930912401753461212240175348142524017534908302401753442174240175349114124017534849902401753487311240175344404824017534606352401753482002240175345712324017534833752401753481906240175348937724017534933812401753488202240175345027824017534861302401753465630240175344337924017534771072401753452098240175345372924017534636292401753464671240175348598024017534463562401753492186240175346217224017534473152401753453248240175344558824017534796992401753492964240175348702124017534592402401753485867240175348540924017534775722401753446646240175346041324017534799412401753481166240175346092524017534559762401753453538240175346793124017534874342401753465159240175349144824017534836412401753468518240175347728224017534888062401753492056240175349051924017534829272401753472089240175347398724017534566452401753467450240175349249024017534727512401753458373240175347744224017534817462401753492810240175346976824017534438502401753484815240175348526324017534653402401753467740240175347832624017534917692401753493541240175347919424017534688912401753449111240175344289124017534476982401753444826240175348791524017534867032401753450087240175346582124017534482752401753489636240175347332124017534897802401753472942240175348864624017534694782401753450568240175347189124017534597212401753468808240175345575424017534838252401753460208240175345104624017534525792401753448923240175347680324017534737962401753469959240175348890524017534452052401753476384240175346726924017534919292401753481272240175346275224017534577032401753484273240175346391924017534906702401753446165240175345228924017534667812401753449784240175347062724017534801212401753489216240175348215624017534932372401753486291240175344959324017534802822401753456263240175347081824017534555632401753482477240175344308924017534458782401753445014240175347949124017534835592401753491264240175347043624017534624622401753463339240175346410724017534552732401753453057240175348953724017534471242401753487755240175345645424017534737032401753488486240175345171824017534883252401753478890240175346159524017534204862401753472461240175347227024017534580832401753471808240175346304924017534798592401753471471240175345866324017534648622401753487595240175344280824017534839312401753468228240175349010624017534527602401753485560240175348994024017534810122401753477763240175344950024017534764902401753451237240175345152724017534790952401753486864240175348454924017534476052401753446837240175346640824017534542142401753473512240175345779624017534871822401753442518240175349026724017534937012401753488073240175348409924017534549792401753480855240175347804324017534806952401753483108240175347851724017534903732401753478609240175345200524017534487322401753466491240175344788924017534787912401753484693240175344529824017534545972401753490991240175347700824017534595302401753454504240175345809024017534552802401753493244240175349068724017534685252401753451534240175347880724017534497082401753479705240175349355824017534879222401753473338240175347862324017534867272401753492988240175349193624017534641142401753492209240175344789624017534831152401753447612240175348500324017534826442401753489384240175346276924017534827502401753481753240175348979724017534794082401753481180240175347314724017534672762401753456270240175345403024017534712972401753462479240175346679824017534704432401753469966240175344732224017534780502401753485898240175344300324017534923462401753452777240175344617224017534438672401753485737240175346746724017534799652401753477879240175345220324017534783332401753445885240175345105324017534937182401753479101240175347371024017534710132401753468235240175344357724017534798662401753470252240175348760124017534870382401753485423240175346487924017534487492401753490274240175348516424017534532552401753472768240175348646824017534888132401753491004240175348438924017534823232401753476827240175346064224017534775962401753469485240175347711424017534883492401753490113240175345973824017534505752401753460932240175348473024017534785242401753472478240175345076624017534810292401753490410240175348383224017534861472401753451244240175348995724017534455022401753489223240175347181524017534537362401753466125240175348630724017534602152401753420493240175345258624017534621892401753479200240175344434524017534829342401753456942240175345713024017534595472401753483665240175345479524017534482822401753464497240175349209424017534802992401753485300240175346919524017534530642401753455983240175348965024017534697752401753488653240175344780324017534720962401753453545240175348455624017534564612401753452012240175344502124017534428152401753480138240175348776224017534466532401753463636240175347082524017534549862401753468815240175346670524017534841052401753476391240175344559524017534832142401753477770240175349266724017534679482401753488912240175348849324017534839862401753454511240175344893024017534895442401753486000240175348203324017534789062401753469102240175347729924017534782342401753449517240175344218124017534618922401753473994240175348338224017534633462401753465838240175345172524017534589602401753491776240175344684424017534600242401753460437240175346775724017534804592401753488080240175345229624017534712042401753446363240175344405524017534618092401753455570240175346564724017534842802401753466989240175346641524017534739012401753450285240175348356624017534871992401753457420240175348216324017534814322401753464404240175346151924017534433862401753490847240175348687124017534766982401753487458240175348070124017534931452401753491462240175344309624017534491282401753492506240175345665224017534774972401753442525240175347701524017534452122401753458380240175348482224017534812892401753490533240175348557724017534639262401753454702240175347149524017534612292401753491318240175345800724017534542212401753464688240175348906324017534706342401753491615240175344453624017534805892401753472959240175347228724017534824842401753487359240175348086224017534765062401753463056240175348159324017534592572401753447131240175345771024017534557782401753458670240175349117224017534500942401753493398240175344483324017534735292401753465357240175347200324017534651662401753479507240175344979124017534819132401753492827240175348824024017534502922401753443584240175348119724017534823302401753491363240175348176024017534729662401753454993240175347987324017534694922401753443874240175347683424017534562872401753482187240175345423824017534806262401753478531240175346335324017534540472401753483849240175345326224017534428222401753478067240175346248624017534577272401753481326240175348265124017534855842401753457437240175348882024017534583042401753487939240175344971524017534890872401753484839240175346219624017534861612401753471020240175345868724017534883702401753447148240175345558724017534860482401753464121240175344733924017534901202401753487625240175347670424017534564782401753473536240175348103624017534667122401753489551240175344820624017534440622401753467283240175347789324017534906942401753479118240175345529724017534870452401753493725240175347121124017534549002401753488257240175349028124017534771452401753480145240175348969824017534720102401753467474240175349267424017534831222401753461816240175349236024017534606592401753477602240175348590424017534898032401753477022240175346488624017534664222401753462776240175347864724017534886602401753492834240175349147924017534425322401753458397240175344580924017534885092401753489964240175346699624017534621032401753467955240175346469524017534592642401753493152240175346776424017534797122401753487779240175348939124017534651732401753484563240175349178324017534502092401753471822240175346123624017534782582401753492247240175345077324017534737272401753485447240175347248524017534794152401753483573240175345259324017534487562401753446370240175347778724017534803052401753492100240175347140224017534773052401753469973240175344339324017534478102401753470641240175348688824017534547192401753478944240175348160924017534864752401753484297240175346393324017534455192401753465654240175347924824017534691192401753485171240175344330024017534775032401753448503240175347334524017534840202401753483238240175348072524017534708322401753464411240175347315424017534530712401753455785240175348574424017534722942401753490441240175345221024017534450382401753466903240175346584524017534559902401753482491240175344210524017534661322401753476414240175347881424017534829412401753486734240175345695924017534515412401753463063240175349162224017534799722401753491189240175349341124017534740072401753482071240175346460224017534836722401753480466240175347026924017534697822401753472775240175346094924017534783402401753491011240175344618924017534566692401753453743240175344666024017534925132401753487496240175345202924017534819202401753445229240175344913524017534844022401753451060240175347161724017534527842401753487366240175346853224017534495242401753493282240175348631424017534443522401753463643240175345250024017534722012401753454528240175348339924017534739182401753448947240175347651324017534448402401753491943240175346536424017534571472401753443010240175348411224017534694092401753468822240175349085424017534600312401753450582240175345000124017534814492401753446851240175348720524017534445432401753484747240175348087924017534682422401753458014240175348896724017534602222401753459745240175345173224017534604512401753479545240175345125124017534421982401753485010240175348279824017534892302401753485331240175347045024017534929952401753493565240175344589224017534905572401753447629240175345897724017534880972401753459554240175345355224017534615262401778215449240175348502724017534786852401753490861240175349057124017534491422401753453088240175346672924017534458162401753477794240175346566124017534797292401753456294240175346912624017534795832401753456676240175347836424017534902982401753453569240175348403724017534644282401753476858240175345550124017534677712401753483580240175348000824017534510772401753448527240175348209524017534497222401753447155240175345203624017534770392401753471631240175347221824017534776402401753461533240175348867724017534798802401753472973240175348737324017534773122401753454245240175346307024017534819372401753446677240175348940724017534606662401753485348240175348982724017534704672401753480152240175345174924017534583112401753473734240175347335224017534829582401753481203240175347392524017534648002401753444369240175346394024017534804732401753442839240175347652024017534879462401753488417240175348136424017534495312401753493732240175346748124017534651802401753464619240175344523624017534720272401753459271240175345222724017534779472401753489971240175344895424017534425492401753444857240175345715424017534917902401753489728240175345279124017534540542401753450506240175345802124017534421122401753493008240175347751024017534922782401753446103240175344876324017534838562401753450216240175348412924017534792862401753487052240175347122824017534669102401753469799240175349268124017534826682401753482354240175348444024017534430272401753469980240175348485324017534664392401753478074240175348518824017534473462401753445045240175347642124017534577342401753445526240175347854824017534910282401753469416240175348763224017534810432401753456201240175347141924017534907002401753483283240175349253724017534803122401753451558240175346095624017534923912401753472492240175344456724017534837022401753470849240175348063324017534817772401753460048240175346336024017534875332401753462783240175348146324017534872122401753459561240175347065824017534602392401753491516240175348591124017534860792401753456485240175345270824017534831392401753451268240175346365024017534500182401753458694240175345696624017534834052401753471839240175348648224017534545352401753471037240175344240224017534435082401753461823240175348852324017534682592401753486178240175346124324017534771832401753443317240175347899924017534532792401753454726240175348956824017534438812401753486901240175347316124017534586012401753464893240175345491724017534788212401753453750240175344407924017534782652401753462400240175348883724017534919502401753484754240175345251724017534461962401753467290240175348161624017534688392401753480732240175345744424017534822172401753491387240175348924724017534641382401753491646240175344638724017534624932401753443591240175348430324017534661492401753493572240175346585224017534791252401753487786240175348632124017534855912401753467207240175344821324017534911962401753490458240175345559424017534702762401753484570240175346047524017534857512401753482842240175348910024017534767112401753479422240175348088624017534589842401753493169240175345975224017534921172401753455204240175346537124017534724092401753493329240175344763624017534740142401753488998240175348548524017534507802401753488103240175346796224017534735432401753486789240175346854924017534901372401753493435240175346970624017534505992401753488264240175348250724017534621102401753446868240175347278224017534928412401753455792240175344782724017534793232401753452234240175345108424017534571612401753460253240175345591424017534722252401753444086240175344896124017534785552401753493015240175345649224017534924382401753467214240175348285924017534636672401753482361240175348754024017534885302401753486925240175348941424017534868192401753477527240175347184624017534882712401753477800240175346096324017534463942401753446875240175348178424017534780812401753481371240175348535524017534851952401753473369240175347402124017534790332401753487809240175348900124017534452432401753471655240175346414524017534549242401753483412240175344954824017534491592401753449739240175347066524017534505132401753450797240175346481724017534898582401753491035240175345175624017534731782401753490144240175348576824017534810502401753485515240175344630124017534806402401753459769240175344668424017534908782401753444376240175348561424017534651972401753470856240175346279024017534618302401753464435240175348004624017534664462401753484310240175345022324017534872292401753459288240175344255624017534859282401753491554240175346615624017534448642401753454252240175345803824017534739322401753465869240175345002524017534864992401753484877240175349285824017534767282401753448770240175346212724017534656782401753470474240175349046524017534714262401753468846240175346510424017534899952401753484761240175345328624017534685562401753482255240175347798524017534445742401753476865240175348297224017534933362401753484143240175344212924017534773292401753487380240175346826624017534574512401753492544240175349359624017534595782401753481494240175349180624017534615402401753458908240175346971324017534937492401753457741240175347943924017534934802401753460673240175347279924017534921242401753492285240175345204324017534530022401753442419240175345357624017534803292401753447353240175346308724017534913942401753488684240175348210124017534586182401753472706240175347962024017534772372401753451565240175345406124017534545422401753452524240175346005524017534892612401753479736240175348121024017534691332401753467979240175344582324017534770462401753483740240175347355024017534819442401753448541240175346270724017534826752401753486338240175349120224017534870692401753493176240175347653724017534669272401753482514240175347374124017534677882401753469423240175349269824017534845872401753455518240175347837124017534838632401753483320240175347104424017534903042401753446110240175344389824017534604822401753442846240175345473324017534674982401753466736240175348767024017534897352401753448220240175348914824017534798972401753491653240175345521124017534835972401753464626240175345376724017534455332401753472416240175348077024017534633772401753488110240175345271524017534840442401753472034240175345640924017534562182401753477657240175348795324017534699042401753450704240175344332424017534512752401753484488240175348017624017534699972401753486215240175345899124017534653882401753483146240175346241724017534674052401753478722240175348163024017534895752401753491967240175347644524017534612502401753478272240175344505224017534557092401753443805240175346395724017534435152401753447162240175344783424017534808932401753480480240175344303424017534476432401753488844240175349058824017534583282401753471235240175345309524017534907172401753472980240175347883824017534850342401753486086240175345668324017534702832401753456973240175347913224017534884312401753473185240175346530224017534804972401753460277240175345272224017534716622401753479149240175347800524017534837882401753479743240175349271124017534450692401753443812240175345023024017534510912401753489421240175345377424017534615572401753457758240175346539524017534815482401753482538240175349245224017534819512401753464442240175349169124017534921312401753464633240175349140024017534856212401753484921240175346991124017534500322401753489582240175349121924017534557162401753487397240175346568524017534430412401753467986240175347048124017534906182401753491561240175348708324017534722322401753448787240175347766424017534863522401753451008240175348928524017534545592401753468273240175344736024017534466912401753478289240175345224124017534517632401753484594240175344487124017534566902401753467412240175348227924017534425632401753484501240175345493124017534505202401753466743240175348682624017534875572401753493602240175347809824017534900072401753460062240175344916624017534816472401753493503240175345071124017534826822401753447650240175346722124017534933432401753467702240175347290424017534729972401753493756240175349181324017534532932401753452050240175346242424017534773362401753467795240175346856324017534903112401753477817240175347935424017534772442401753478418240175349088524017534865052401753484150240175347394924017534890182401753483870240175348240824017534764522401753471433240175347856224017534530192401753466163240175344438324017534571782401753470290240175344717924017534636742401753458335240175348812724017534702072401753476889240175344554024017534740382401753463094240175348869124017534512822401753485201240175347673524017534810672401753472713240175347705324017534879602401753455228240175347356724017534547402401753447841240175348315324017534928652401753486970240175349197424017534817912401753470672240175347990324017534790572401753478845240175344458124017534806572401753481388240175346511124017534669342401753488288240175349229224017534495552401753459295240175347944624017534891792401753472423240175348008424017534853622401753490731240175348771724017534847782401753476544240175348857824017534569802401753464152240175346587624017534812272401753469430240175344856524017534440002401753462134240175345593824017534801832401753469720240175346338424017534461272401753485041240175344352224017534859352401753446882240175348552224017534737582401753453583240175345746824017534925822401753455525240175348577524017534884482401753448978240175348081724017534424332401753469140240175345660724017534597762401753471242240175346126724017534821182401753445250240175347204124017534540782401753470863240175345891524017534664532401753443331240175348033624017534532002401753448237240175345157224017534627142401753456416240175346184724017534421362401753477534240175344660824017534796512401753464824240175345804524017534718532401753482866240175347105124017534834292401753478753240175344583024017534836032401753482989240175345253124017534639642401753463001240175348091624017534910422401753446318240175348333724017534888512401753460680240175348609324017534592022401753459585240175348723624017534901512401753493183240175344409324017534843272401753449746240175345862524017534609702401753489896240175348405124017534688532401753487830240175346049924017534897422401753456225240175347337624017534930222401753490472240175345426924017534862532401753442853A36489156A36489161A36489171A36489176A36489181A36489186A36489191A3648919627 +es_ESVPR274981090VPR395A36489166 +es_ES(Personaliza tu sofá999.35882987013 +es_ES(Personaliza tu sofá +1.000 +es_ES.Sofás_nueva jerarquía999.35882986013 +es_ES Sofás +6.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN0338152 +es_ES6MOBEL YECLA TAPIZADOS, S.L. +es_ESbSofá tapizado de 2 plazas Luton El Corte Inglés +pt_PTO sofá Luton é a representação do conforto. Um design tradicional, com costas e assentos rectos, para dar firmeza ao assento, e apoios para braços em forma de almofada para lhe permitir aproveitar essa parte do sofá se o que gosta é recostar-se por completo.De formas quadradas, robustas, este sofá é resistente e duradouro, também pode ser usado diariamente. Combina bem com diferentes ambientes, pode integrá-lo numa decoração mais clássica ou em espaços contemporâneos. +es_ESEl sofá Luton es la representación del confort. Un diseño tradicional, con respaldos y asientos rectos, para dar firmeza a la sentada, y reposabrazos en forma de almohadón para permitirte aprovechar esa parte del sofá si lo que te gusta es recostarte por completo.De formas cuadradas, robustas, este sofá te resultará resistente y duradero, además de permitirte darle un uso diario. Muy combinable en diferentes ambientes, puede integrarlo en una decoración más clásica o en espacios contemporáneos.A36489166123707056EL CORTE INGLES +es_ESEL CORTE INGLES0338152 +es_ES6MOBEL YECLA TAPIZADOS, S.L.998.00209 +es_ESMuebles998.00206 +es_ES +Hogar998 +es_ES@Jerarquía de Ficha de Productos +colorLUTON903 +es_ESbSofá tapizado de 2 plazas Luton El Corte Inglés +es_ESbSofá tapizado de 2 plazas Luton El Corte Inglés +es_ESMuestrario233776090Muestrario +es_ESMuestrario +10107 +pt_PTO sofá Luton é a representação do conforto. Um design tradicional, com costas e assentos rectos, para dar firmeza ao assento, e apoios para braços em forma de almofada para lhe permitir aproveitar essa parte do sofá se o que gosta é recostar-se por completo.De formas quadradas, robustas, este sofá é resistente e duradouro, também pode ser usado diariamente. Combina bem com diferentes ambientes, pode integrá-lo numa decoração mais clássica ou em espaços contemporâneos. +es_ESEl sofá Luton es la representación del confort. Un diseño tradicional, con respaldos y asientos rectos, para dar firmeza a la sentada, y reposabrazos en forma de almohadón para permitirte aprovechar esa parte del sofá si lo que te gusta es recostarte por completo.De formas cuadradas, robustas, este sofá te resultará resistente y duradero, además de permitirte darle un uso diario. Muy combinable en diferentes ambientes, puede integrarlo en una decoración más clásica o en espacios contemporáneos. calificacion1CDcalificacion2Ecalificacion3Bcalificacion4VVcalificacion5ADcalificacion6EE06$WITHDRAWAL_SERVICEpler4twpwa2rdqpg2vhuoamrluxipaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-03T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-06T05:33:22.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02020-06-25T22:00:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE$ONEa4v6ww5dsrrike ENTITY{"identifier":"NO","name":[{"value":"NO","locale":"es_ES"}],"external_identifier":"21516242090","description":[{"value":"NO","locale":"es_ES"}],"type_lookup":"2564"}MANYabvdbs2rdyeoxoCOMPLEX {"alyalisglnj6pk":{"identifier":"Estructura","name":[{"value":"Estructura","locale":"es_ES"}],"external_identifier":"234707090","description":[{"value":"Estructura","locale":"es_ES"},{"value":"Estrutura","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":1,"amw3djmoazi23q":[{"arlfkckof3nhrq":100.0,"amifyxm5h4vona":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a5kkuujbfaypya":{"identifier":"Madera de pino y aglomerado","name":[{"value":"Madera de pino y aglomerado","locale":"es_ES"}],"external_identifier":"7594726090","description":[{"value":"Legno di pino e conglomerato","locale":"it_IT"},{"value":"Pine wood and particleboard","locale":"en_GB"},{"value":"Madera de pino y aglomerado","locale":"es_ES"},{"value":"Bois de pin et aggloméré","locale":"fr_FR"},{"value":"Madeira de pinho e aglomerado","locale":"pt_PT"}],"type_lookup":"194"}}]} @NULL@{"alyalisglnj6pk":{"identifier":"Patas","name":[{"value":"Patas","locale":"es_ES"}],"external_identifier":"234714090","description":[{"value":"Patas","locale":"es_ES"},{"value":"Pés","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":4,"amw3djmoazi23q":[{"arlfkckof3nhrq":100.0,"amifyxm5h4vona":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a5kkuujbfaypya":{"identifier":"Madera de Haya","name":[{"value":"Madera de Haya","locale":"es_ES"}],"external_identifier":"372319090","description":[{"value":"Legno di Faggio","locale":"it_IT"},{"value":"Beech wood","locale":"en_GB"},{"value":"Madera de Haya","locale":"es_ES"},{"value":"Bois de Hêtre","locale":"fr_FR"},{"value":"Madeira de faia","locale":"pt_PT"}],"type_lookup":"194"}}]}{"alyalisglnj6pk":{"identifier":"Asiento","name":[{"value":"Asiento","locale":"es_ES"}],"external_identifier":"234688090","description":[{"value":"Asiento","locale":"es_ES"},{"value":"Assento","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":2}{"alyalisglnj6pk":{"identifier":"Respaldo","name":[{"value":"Respaldo","locale":"es_ES"}],"external_identifier":"234725090","description":[{"value":"Respaldo","locale":"es_ES"},{"value":"Costas","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":2}{"alyalisglnj6pk":{"identifier":"Reposabrazos","name":[{"value":"Reposabrazos","locale":"es_ES"}],"external_identifier":"234724090","description":[{"value":"Reposabrazos","locale":"es_ES"},{"value":"Braços","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":2,"amw3djmoazi23q":[{"arlfkckof3nhrq":100.0,"amifyxm5h4vona":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a5kkuujbfaypya":{"identifier":"Poliuretano recubierto de fibra","name":[{"value":"Poliuretano recubierto de fibra","locale":"es_ES"}],"external_identifier":"480900090","description":[{"value":"Poliuretano ricoperto di fibra","locale":"it_IT"},{"value":"Fibre-coated polyurethane","locale":"en_GB"},{"value":"Poliuretano recubierto de fibra","locale":"es_ES"},{"value":"Polyuréthanne recouvert de fibre","locale":"fr_FR"},{"value":"Poliuretano com cobertura de fibra","locale":"pt_PT"}],"type_lookup":"194"}}]}ONEaenyfxjcnnqhd2 ENTITY{"identifier":"Sofás de 2 plazas","name":[{"value":"Sofás de 2 plazas","locale":"es_ES"}],"external_identifier":"235096090","description":[{"value":"Sofás de 2 plazas","locale":"es_ES"}],"type_lookup":"10042"}ONEagusnbyzvvsh7u NUMBER77MANYagv3lrjucyrexmCOMPLEX{"abmqasrofr6ncu":{"identifier":"No","name":[{"value":"No","locale":"es_ES"}],"external_identifier":"347406090","description":[{"value":"No","locale":"en_GB"},{"value":"No","locale":"es_ES"},{"value":"Non","locale":"fr_FR"},{"value":"Não","locale":"pt_PT"}],"type_lookup":"144"}}ONEagxzafqhy5pkgg NUMBER94MANYaiowsh755gtziu STRING[{"locale":"es_ES","value":["Este producto es personalizado y no admite devolución."]}]ONEakzzyg4snb6u42 ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}ONEalih4mlm2oj5qy NUMBER156MANYall7jshlgswax4 STRING[{"locale":"es_ES","value":["Por favor, asegúrese de que todos los accesos al domicilio tienen las medidas necesarias para la entrega de la mercancía. En caso de ser necesario desmontaje y montaje del artículo, poner una grúa o cualquier otra gestión adicional requerida para poder realizar la entrega, los costes de estos servicios serán asumidos por el cliente."]}]ONEamqcbfmzbopfde ENTITY{"identifier":"2 Plazas","name":[{"value":"2 Plazas","locale":"es_ES"}],"external_identifier":"234683090","description":[{"value":"2 Plazas","locale":"es_ES"}],"type_lookup":"10102"}ONEaopyy33i6kpc3y ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}ONEar6gp3jqldrbt4 ENTITY{"identifier":"No","name":[{"value":"No","locale":"es_ES"}],"external_identifier":"347406090","description":[{"value":"No","locale":"es_ES"}],"type_lookup":"144"}ONEato6duzhihm4g4 ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}ONEatpgrmvd6q6dxy NUMBER42MANYayehwror5k5tas ENTITY{"identifier":"Tapizado","name":[{"value":"Tapizado","locale":"es_ES"}],"external_identifier":"349971090","description":[{"value":"Tapizado","locale":"es_ES"}],"type_lookup":"194"}MANYazjue4n64ntcka ENTITY{"color_code":"Gris","color_description":[{"value":"Gris","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Gris","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png","size":"small"}],"description":[{"value":"Gris","locale":"es_ES"}],"identifier":"4940","name":[{"value":"COLOR_GRIS","locale":"es_ES"}],"external_identifier":"599650054"},"identifier":"Gris","name":[{"value":"Gris","locale":"es_ES"}],"external_identifier":"344777090"}ONEaztnv4kkljcyro STRING Cincha elásticaMuebles_ISS.SPEC_SECONDARY_TEMPLATE +es_ESSupervoluminoso348626090Supervoluminoso +es_ESSupervoluminoso401$000000000149594219(2020-06-25T22:00:01Z(2022-10-06T05:33:22Z"2022-10-03T22:00Z$001012800511201 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore 16Hcd50cc4a-d524-4fe0-bdc7-c5ad836502aa DELETE<2023-09-02T17:30:36.014388660Z4dataloader-mongo-kafka-job62023-09-02T17:31:07.345882Z(mixer-gtin-agr-kfreeH6f3ce0f9-61b4-4e76-b900-bc0f7e8c7fb262023-09-02T17:32:51.642511Z,mixer-gtin-calc-pcsflmH47eaed1c-ff72-436f-9149-89225e0c14ee62023-09-02T17:32:56.312836Z,mixer-gtin-calc-pcsflmHc85709ea-e77b-4a47-a45c-73d190a629ff62023-09-03T02:48:07.953830Z0mixer-product-calc-kfreeH12055447-3ade-438d-8708-e5d1de009209<2024-01-19T11:18:46.930514564Z$mixer-xsell-mixtriHd2fb7d18-6745-4add-8509-c49528c6279762024-01-19T11:18:47.061822Z4mixer-packing-units-mixtriH1a4f08ac-4e2a-4760-bbe9-73e15036153a62024-01-19T11:18:47.647411Z.mixer-offer-badge-mixbiH29d6548e-27d7-4406-8819-a84efb45b78662024-01-19T11:25:56.186331Z.mixer-offer-badge-mixbiH465ff789-268c-4f3f-961e-586fb415ee21(7×c,7ǻmf! + +Joffer(A4477990).publish_ends_extendedIVA08IGIC90 +50307001V00651153513001225VALDEMORO +es_ESVALDEMOROCOMPRA EN FIRME +es_ESCOMPRA EN FIRME*LECTURAS RECOMENDADAS +es_ES*LECTURAS RECOMENDADASSTERLING +es_ESSTERLING$001006522550307 "2018-02-07T23:00Z97884835789020(2012-03-01T16:11:44Z +es_ES$CRIMSON HERO Nº141 +es_ES Libros274977090 Libros3959788483578902$0000000001008697062401325074581162559056 GLENAT +es_ES GLENAT +es_ES Shonen999.4366886013 +es_ES Shonen +5.000 +es_ES +Manga999.4366881013 +es_ES +Manga +3.000 +es_ESCómics999.4366876013 +es_ESCómics 13.000 +es_ES Libros999.54302013 +es_ES LibrosNNNN1 +es_ES Libros274977090 Libros395A4477990 +es_ES Shonen999.4366886013 +es_ES Shonen +5.000 +es_ES +Manga999.4366881013 +es_ES +Manga +3.000 +es_ESCómics999.4366876013 +es_ESCómics 13.000 +es_ES Libros999.54302013 +es_ES LibrosNNNN5587491602032995 +es_ES0EDITORES DE TEBEOS (EDT) ,- - ()  +es_ES$Crimson hero nº14 +es_ESLo que más desea Nobara es jugar al voleibol, cueste lo que cueste y diga lo diga su madre.A4477990162559056 GLENAT +es_ES GLENAT6264621600583815 +es_ES4DIRAC DIST S.L._recargaNFTCALLE MONTSIA, 9-11.P.I.CAN BERNADES,..-08130 SANTA PERPETUA DE MOGODA - BARCELONA (ESPAñA) 998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de Productos9788483578902 +es_ES$Crimson hero nº14 +es_ES$Crimson hero nº14 +es_ESLo que más desea Nobara es jugar al voleibol, cueste lo que cueste y diga lo diga su madre. +calificacion1Acalificacion2Acalificacion3E5calificacion4VVcalificacion5AC00pler4twpwa2rdqpkcwmvhkxxd52gpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"010","name":[{"value":"010","locale":"es_ES"}],"external_identifier":"233767090","description":[{"value":"Gestión Automática - Publica despublicadas con stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02023-01-19T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02009-08-27T22:00:00.000ZONEate3liesiuooycBOOLEANtrueONEafabpb3cbt6g3oTIMESTAMP02023-02-15T23:00:01.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa3aauuktnvama2 ENTITY{"identifier":"1053207","name":[{"value":"MITSUB TAKANASHI","locale":"es_ES"}],"external_identifier":"500940051","given_name":"MITSUB","family_name":"TAKANASHI","birth_place":[],"death_place":[],"biography":[],"media_objects":[],"normalized_name":"mitsub-takanashi"}ONEa3novp2ls57ixm STRINGH[{"locale":"es_ES","value":"MANGA"}]ONEa5ej6iwjweshes STRING001ONEacnblp3uq557wk STRING002ONEadwyeen33wnwra STRING008ONEaj6qadcmhrezii NUMBER184ONEangal4rqdmxpse STRINGH[{"locale":"es_ES","value":"COMIC"}]ONEaogwgan32v4m66 STRINGAGMANYaoyr2i73cpmiu6 ENTITY{"identifier":"Castellano","name":[{"value":"Castellano","locale":"es_ES"}],"external_identifier":"347423090","description":[{"value":"Castellano","locale":"es_ES"}],"type_lookup":"157"}ONEau4wikbtn4ylzk STRING$Crimson hero nº14MANYa5n7q7yo7vv4mmCOMPLEX[{"locale":"es_ES","value":[{"aboxfxr6aqfxku":["Lo que más desea Nobara es jugar al voleibol, cueste lo que cueste y diga lo diga su madre."]}]}]MANY*libros_iss_calculatedCOMPLEX{"name":"MITSUB TAKANASHI","rol":"Autor","grouper":"author","normalize_name_grouper":"author|mitsub-takanashi"}Libros_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000100869706"2009-08-27T22:00ZDVD(2023-02-15T23:00:01Z"2023-01-19T23:00Z$001006522550307 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hf825aacb-78fc-4402-a20e-6930a59ae203 DELETE<2023-09-02T18:33:33.160501150Z4dataloader-mongo-kafka-job62023-09-02T18:51:11.499395Z(mixer-gtin-agr-kfreeH2d612b13-f4b4-4193-b6e0-950530e1bd3d62023-09-02T20:05:31.915186Z,mixer-gtin-calc-pcsflmH6bdd4131-15b8-462f-9553-0dfe9128472462023-09-02T20:05:41.415959Z,mixer-gtin-calc-pcsflmH71feaa2d-fdfa-41d3-b686-824f23069b9962023-09-03T02:21:31.263971Z0mixer-product-calc-kfreeH8daeddae-a631-4d28-89b5-89e96dbf3f7e<2024-01-19T11:18:00.371665325Z$mixer-xsell-mixtriH32c09064-79b1-4275-9cc5-5cbb5518769762024-01-19T11:18:00.480259Z4mixer-packing-units-mixtriH5d296f88-b92b-4963-b6e4-0c932ec3c8a062024-01-19T11:18:47.924891Z.mixer-offer-badge-mixbiH4c6246f9-73de-48d3-94db-f2149b5db3a362024-01-19T11:25:56.189143Z.mixer-offer-badge-mixbiH6ec64ac4-af5a-428b-9173-4d95a89162ca(7×cJoffer(A7792517).publish_ends_extendedIVA02IGIC92 +1232600100511677275001420VALDEMORO +es_ESVALDEMOROCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001005142012326 "2012-11-05T23:00Z2051420123266"2012-11-05T23:00Z00967412296260(2012-11-27T08:45:33Z +es_ESMEDITERRANEAN7 +es_ES Discos274975090 Discos395ML +es_ESml +1.0000096741229626$0000000001004749912401450548124898237056SOMERSET +es_ESSOMERSET +es_ESdAmbiental - Relajación - Sonidos de la Naturaleza999.5224817013 +es_ESdAmbiental - Relajación - Sonidos de la Naturaleza +1.000 +es_ES4Ambiental y de relajación999.4974622013 +es_ES4Ambiental y de relajación 16.000 +es_ESMúsica999.54175013 +es_ESMúsicaNNN7 +es_ES Discos274975090 Discos395A7792517 +es_ESdAmbiental - Relajación - Sonidos de la Naturaleza999.5224817013 +es_ESdAmbiental - Relajación - Sonidos de la Naturaleza +1.000 +es_ES4Ambiental y de relajación999.4974622013 +es_ES4Ambiental y de relajación 16.000 +es_ESMúsica999.54175013 +es_ESMúsicaNNN6255701600569749 +es_ESCAT MUSIC, S.L.CALLE BERLIN(PG IND EUROPOLIS)NV 10A,.-28232 LAS ROZAS - MADRID (ESPAñA)  +es_ES,Mediterranean Spa (CD)A77925176255701600569749 +es_ES4CAT MUSIC, S.L._recargaNFTCALLE BERLIN(PG IND EUROPOLIS)NV 10A,.-28232 LAS ROZAS - MADRID (ESPAñA) 998.00078 +es_ESMúsica998.00077 +es_ESMúsica998 +es_ES@Jerarquía de Ficha de Productos +46474 +es_ES,Mediterranean Spa (CD) +46474 +es_ES,Mediterranean Spa (CD) +calificacion1D1calificacion2Ocalificacion3MTcalificacion4VVcalificacion5B06pler4twpwa2rdqpotazgohmkmafk&MANYa5hilbj32lamhqCOMPLEX{"apj2uzph6fmmkk":1,"acmt6g7r6qhx2u":[{"atc6bkopc4nzvg":9.07,"au7f4xdiq7un2c":"The Shimmering","a4ry3szh3gtire":1}],"avgcdiqt7a2aza":{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"346108090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"727"}}ONEafo2anbgjhsm24 STRING`[{"locale":"es_ES","value":"MUSICAS DEL MUNDO"}]ONEagicfmz77ja53a STRINGz[{"locale":"es_ES","value":"OTRASRECOPILACIONES M.DELMUNDO"}]ONEah5ay5gxswthzi ENTITY{"identifier":"DDD","name":[{"value":"DDD","locale":"es_ES"}],"external_identifier":"346126090","description":[{"value":"DDD","locale":"es_ES"}],"type_lookup":"726"}ONEahfff3nxlhwulu STRINGCBONEajpdzknt6uts6y ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"347028090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"755"}MANYal3xisuwvftmyk ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"10121506090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"910"}ONEaoebsmn4ezopnm STRING003ONEap2hatgiudxb3e STRING"MEDITERRANEAN SPAONEap7y5h3tps6gkg STRING005MANYaqrilmr6vaykxs NUMBER1ONEara2vukzeq2ngmTIMESTAMP02012-11-14T23:00:00.000ZONEarivs247bp3ifs ENTITY{"identifier":"estudio","name":[{"value":"estudio","locale":"es_ES"}],"external_identifier":"346127090","description":[{"value":"estudio","locale":"es_ES"}],"type_lookup":"735"}ONEarnjhlabcabx7u STRING005MANYav6kjmaio2grso ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"347028090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"755"}ONEav7wm2uhmbgqwk STRINGGIBSON, DANMANYavajjx54jfzn6kCOMPLEX{"agpvq6oxw255wq":[{"ao2qh3g5n6csh4":{"identifier":"000009","name":[{"value":"Varios","locale":"es_ES"}],"external_identifier":"125396055","given_name":"Varios"}}],"aelpy27erl64ea":{"identifier":"Artista","name":[{"value":"Artista","locale":"es_ES"}],"external_identifier":"42203958090","description":[{"value":"Artista","locale":"es_ES"}],"type_lookup":"732"}}ONEazfp567bhee4hs STRINGN[{"locale":"es_ES","value":"SOMERSET"}]MANY*musica_iss_calculatedCOMPLEX{"name":"Varios","rol":"Artista","grouper":"musicCast","normalize_name_grouper":"musicCast|varios"}Musica_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02023-02-10T01:44:49.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02012-11-27T08:46:33.000ZONEate3liesiuooycBOOLEAN +falseONEafabpb3cbt6g3oTIMESTAMP02023-02-11T01:44:49.000ZONEakzd7vzeui6lmu STRINGDFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000100474991(2012-11-27T08:46:33ZDVD(2023-02-11T01:44:49Z(2023-02-10T01:44:49Z$001005142012326 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H5f8d9d20-1f67-41f8-939a-3e58d0a52c36 DELETE<2023-09-02T18:34:52.707080201Z4dataloader-mongo-kafka-job62023-09-02T18:59:16.598151Z(mixer-gtin-agr-kfreeH461d3197-7b34-4db3-bebc-4e1646f6739b62023-09-02T20:14:25.810671Z,mixer-gtin-calc-pcsflmH1a275801-32bf-47c3-a70d-6303733387df62023-09-02T20:14:26.619471Z,mixer-gtin-calc-pcsflmHbe8dc67a-965a-4430-a21d-3527f33b069c62023-09-03T02:36:15.919589Z0mixer-product-calc-kfreeH81d34164-6755-4d8f-bf5d-57967d7c6eb2<2024-01-19T11:18:00.247152458Z$mixer-xsell-mixtriHf8f4ae48-500e-4dea-a3c7-8c113274ea7062024-01-19T11:18:00.771294Z4mixer-packing-units-mixtriH527ac33e-17db-4133-816f-1da84959491462024-01-19T11:18:47.940953Z.mixer-offer-badge-mixbiH13072ebb-54ef-42e1-820c-35de066ec70562024-01-19T11:25:56.189725Z.mixer-offer-badge-mixbiH12be9be8-4c3c-4a1f-9d1d-b515309047db(7×cIVA02IGIC91 +1497800102023-02-13T05:41:25.985Z057313764940001263COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001057326314978007&includeAsWebNovelty +es_ESNovedadDVD Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2016-09-22T23:01:27Z +es_ESFIRMAS T.G. +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401997864299$000001426233230007TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401997864299123284056 +MIRTOmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/2/00001269352/00001269352529mM1011.jpg +es_ES +Mirto +es_ESCamisas999.39072754013 +es_ESCamisas +3.000 +es_ESTallas grandes999.39072740013 +es_ESTallas grandes +6.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ESCamisas999.8496053013 +es_ESCamisas +2.000 +es_ES42015 Hombre Tallas Grandes999.8496050013 +es_ES*Hombre Tallas Grandes 23.000 +es_ESModa999.53895013 +es_ESModaNNN2401998250954A18468411A18486764A18504143 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A184729575143471600362624 +es_ES*CREACIONES MIRTO S.A.pCALLE EMILIO MUÑOZ.,57-28037 MADRID - MADRID (ESPAñA)  +es_ESzCamisa de hombre Mirto classic de cuadros azul tallas grandes +es_ESCamisa de manga larga, de microcuadros color azul. Tiene el cuello americano, los puños de arista y lleva un bolsillo en el pecho.Classic FitCómoda y tradicional. Sisa amplia, ancho de manga sin ceñir el brazo y contorno recto hasta el final de la camisa.A18472957123284056 +MIRTO +es_ES +MIRTO5143471600362624 +es_ES*CREACIONES MIRTO S.A.pCALLE EMILIO MUÑOZ.,57-28037 MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize8642 +es_ESzCamisa de hombre Mirto classic de cuadros azul tallas grandes +es_ESzCamisa de hombre Mirto classic de cuadros azul tallas grandes +es_ESCamisa de manga larga, de microcuadros color azul. Tiene el cuello americano, los puños de arista y lleva un bolsillo en el pecho.Classic FitCómoda y tradicional. Sisa amplia, ancho de manga sin ceñir el brazo y contorno recto hasta el final de la camisa. calificacion1Acalificacion2Ocalificacion3RIcalificacion4VVcalificacion5Bcalificacion6I0047934509047 +es_ES47E +es_ESEspañol4793990907 +es_ES7477054090Americano +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02018-06-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02019-06-15T22:00:01.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02016-09-19T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Cuadros","name":[{"value":"Cuadros","locale":"es_ES"}],"external_identifier":"2655615090","description":[{"value":"Cuadros","locale":"es_ES"}],"type_lookup":"2504"}MANYa5r36nvug7ald6 ENTITY{"identifier":"Classic","name":[{"value":"Classic","locale":"es_ES"}],"external_identifier":"12970401090","description":[{"value":"Classic","locale":"es_ES"}],"type_lookup":"1594"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Botones","name":[{"value":"Botones","locale":"es_ES"}],"external_identifier":"2696224090","description":[{"value":"Botones","locale":"es_ES"}],"type_lookup":"1595"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Sport","name":[{"value":"Sport","locale":"es_ES"}],"external_identifier":"347623090","description":[{"value":"Sport","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas","name":[{"value":"Camisas","locale":"es_ES"}],"external_identifier":"347767090","description":[{"value":"Camisas","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Azul","color_description":[{"value":"Azul","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Azul","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png","size":"small"}],"description":[{"value":"Azul","locale":"es_ES"}],"identifier":"15915","name":[{"value":"COLOR_AZUL","locale":"es_ES"}],"external_identifier":"598455054"},"identifier":"Azul","name":[{"value":"Azul","locale":"es_ES"}],"external_identifier":"347189090"}ONEalyk5fczplpqi6 ENTITY{"identifier":"Botón","name":[{"value":"Botón","locale":"es_ES"}],"external_identifier":"2696237090","description":[{"value":"Botón","locale":"es_ES"}],"type_lookup":"1600"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2016Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001426233230007"2016-09-19T22:00Z(2019-06-15T22:00:01Z(2018-06-15T22:00:01Z$001057326314978007001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore007Hdd33c73b-6323-4b03-b462-9562ff99db0f DELETE<2023-09-02T17:13:13.094426304Z4dataloader-mongo-kafka-job62023-09-02T17:13:25.750102Z(mixer-gtin-agr-kfreeHdd3d9721-026f-4500-a24e-864862f3149e62023-09-02T17:13:27.181281Z,mixer-gtin-calc-pcsflmH89dc0dc0-23db-4902-aaa9-ecca2b4ce77c62023-09-02T17:13:36.398048Z,mixer-gtin-calc-pcsflmHed3fc3c6-a953-4451-b825-26f2c3d0915962023-09-03T02:28:48.489616Z0mixer-product-calc-kfreeHb155bf90-203c-4f3a-a912-102310eb8add<2024-01-19T11:18:00.685248303Z$mixer-xsell-mixtriH3e00022a-14a2-4282-8b8c-099941c3111d62024-01-19T11:18:00.870963Z4mixer-packing-units-mixtriH47060ca6-240e-4687-b96a-55bd7f249c9162024-01-19T11:18:47.942708Z.mixer-offer-badge-mixbiH118b44c5-40b7-4050-9278-12cd7480fceb62024-01-19T11:25:56.195392Z.mixer-offer-badge-mixbiH6cc36084-e10a-4f4c-81a4-f521ebded26c(7×cIVA02IGIC91 +8159200102023-04-24T18:12:29.621Z017738312126001312COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001017731281592105 +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31820070090 +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31845113054 +32406 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png +es_ES&POLYESTER_RECICLADO +es_ES&Polyester reciclado +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png020 +es_ES&Polyester reciclado:SUSTAINABILITY_CLOSING_CIRCLE"2021-02-03T23:00Z4064036015113Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco / Burdeos +es_ES Blanco / Burdeos2492518090 +es_ES Blanco / Burdeos2492519054 +14734 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201907/02/14734_5_.png +es_ES BLANCO_/_BURDEOS +es_ES Blanco / Burdeos Blanco / Burdeos +es_ES Blanco / Burdeos0(2021-02-25T23:32:31Z +es_ESCASUAL HOMBRE +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004064036015113$000001509853900105TRADICIONAL +es_ES BLANCO_/_BURDEOS +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201907/02/14734_5_.png2401788255725123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas +es_ES"Calzado deportivo997.32324453011 +es_ES"Calzado deportivo +2.000 +es_ESDeportes997.32324246011 +es_ESDeportes +9.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ES Hombre997.32835414011 +es_ES Hombre +2.000 +es_ES8Zapatillas deportivas casual997.32835412011 +es_ES8Zapatillas deportivas casualCDN +es_ESZapatillas999.2682177013 +es_ESZapatillas +1.000 +es_ES"Zapatos de hombre999.2682140013 +es_ES"Zapatos de hombre +2.000 +es_ES2014 Zapatos999.2682136013 +es_ESZapatos +4.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ES"Casual - Sneakers999.53682013 +es_ES"Casual - Sneakers 10.000 +es_ESCalzado999.53678013 +es_ESCalzado +7.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ES"Casual - Sneakers999.14598473013 +es_ES"Casual - Sneakers +1.000 +es_ES ZapatillasyBotas999.12473891013 +es_ES$Zapatillas y Botas +2.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESCalzado999.53678013 +es_ESCalzado +7.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESZapatos997.38170083011 +es_ESZapatos +2.000 +es_ESModa Hombre997.38150774011 +es_ESModa Hombre +6.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ESZapatillas999.39073065013 +es_ESZapatillas +3.000 +es_ESZapatos999.39072678013 +es_ESZapatos +2.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A387900705788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ESrZapatillas casual de hombre NY 92 Sport adidas Originals +en_GBIf you're looking to put the finishing touches on your casual outfits, opt for the retro look of these adidas shoes. With a classic, minimalist design featuring the legendary 3-stripes and clover logo on the tongue, this model will always be your favourite. In addition to its vintage style, it is a super simple model, which gives it versatility to fit into all your plans. In addition, it has exceptional comfort in its internal template and its soft materials.  +fr_FRSi vous cherchez à mettre la touche finale à vos tenues décontractées, optez pour le look rétro de ces chaussures adidas. Avec un design classique et minimaliste, avec le légendaire logo à trois bandes et trèfle sur la langue, ce modèle sera toujours votre préféré. En plus de son style vintage, c'est un modèle super simple, ce qui lui confère une grande polyvalence pour s'adapter à tous vos projets. De plus, il est d'un confort exceptionnel grâce à son gabarit interne et à ses matériaux souples.  +es_ESSi buscas dar el broche final a tus outfits informales, opta por el arrollador estilo retro de estas zapatillas de adidas. Con un diseño clásico y minimalista protagonizado por las míticas 3 bandas y el logotipo de trébol en la lengüeta, este modelo será siempre tu favorito. Además de destacar por su estilo vintage, es un modelo súper sencillo, lo que le confiere versatilidad para encajar en todos tus planes. Además, cuenta con una comodidad excepcional en su plantilla interna y sus suaves materiales.A38790070123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize H04429 +es_ESrZapatillas casual de hombre NY 92 Sport adidas Originals +es_ESrZapatillas casual de hombre NY 92 Sport adidas Originals +en_GBIf you're looking to put the finishing touches on your casual outfits, opt for the retro look of these adidas shoes. With a classic, minimalist design featuring the legendary 3-stripes and clover logo on the tongue, this model will always be your favourite. In addition to its vintage style, it is a super simple model, which gives it versatility to fit into all your plans. In addition, it has exceptional comfort in its internal template and its soft materials.  +fr_FRSi vous cherchez à mettre la touche finale à vos tenues décontractées, optez pour le look rétro de ces chaussures adidas. Avec un design classique et minimaliste, avec le légendaire logo à trois bandes et trèfle sur la langue, ce modèle sera toujours votre préféré. En plus de son style vintage, c'est un modèle super simple, ce qui lui confère une grande polyvalence pour s'adapter à tous vos projets. De plus, il est d'un confort exceptionnel grâce à son gabarit interne et à ses matériaux souples.  +es_ESSi buscas dar el broche final a tus outfits informales, opta por el arrollador estilo retro de estas zapatillas de adidas. Con un diseño clásico y minimalista protagonizado por las míticas 3 bandas y el logotipo de trébol en la lengüeta, este modelo será siempre tu favorito. Además de destacar por su estilo vintage, es un modelo súper sencillo, lo que le confiere versatilidad para encajar en todos tus planes. Además, cuenta con una comodidad excepcional en su plantilla interna y sus suaves materiales. calificacion1Acalificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MOPD47933509045 y 1/3 +es_ES45 y 1/3E +es_ESEspañol47909709010.5 +es_ES10.518171618090Fabricante +Tallapler4twpwa2rdqphm44qlzhmwa2ypwe2kceprh5w3apaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-08-12T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-08-16T05:48:13.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-02-22T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa7jpc7s7go77wi ENTITY{"identifier":"Textil","name":[{"value":"Textil","locale":"es_ES"}],"external_identifier":"392162090","description":[{"value":"Textil","locale":"es_ES"}],"type_lookup":"1633"}ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Goma","name":[{"value":"Goma","locale":"es_ES"}],"external_identifier":"477871090","description":[{"value":"Goma","locale":"es_ES"}],"type_lookup":"1633"}MANYamzex7cmn57eei ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Sintético","name":[{"value":"Sintético","locale":"es_ES"}],"external_identifier":"477968090","description":[{"value":"Sintético","locale":"es_ES"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Casual","name":[{"value":"Casual","locale":"es_ES"}],"external_identifier":"373606090","description":[{"value":"Casual","locale":"es_ES"}],"type_lookup":"1620"}{"identifier":"Zapatillas","name":[{"value":"Zapatillas","locale":"es_ES"}],"external_identifier":"349403090","description":[{"value":"Zapatillas","locale":"es_ES"}],"type_lookup":"1620"}ONEauur46vhpycka4 ENTITY{"identifier":"Deportivas hombre","name":[{"value":"Deportivas hombre","locale":"es_ES"}],"external_identifier":"349402090","description":[{"value":"Deportivas hombre","locale":"es_ES"}],"type_lookup":"1611"}MANYaxr5m2ljibnmui NUMBER2021Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001509853900105"2021-02-22T23:00ZDVD(2021-08-16T05:48:13Z"2021-08-12T22:00Z$001017731281592105001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore105Ha74f88c8-b05b-4b30-bc4f-02479ef02d29 DELETE<2023-09-02T17:35:06.396605741Z4dataloader-mongo-kafka-job62023-09-02T17:40:18.646321Z(mixer-gtin-agr-kfreeH8bc7e06b-8a49-4875-a479-6591c6eb129962023-09-02T17:51:49.209240Z,mixer-gtin-calc-pcsflmH047a0eee-899e-49d2-bdd0-7852ac7cf2e762023-09-02T17:51:50.716465Z,mixer-gtin-calc-pcsflmH397d709c-ac5a-4891-b0d9-7f2b840386e062023-09-03T02:55:36.767154Z0mixer-product-calc-kfreeHf8138b64-f7ed-4dbe-93ab-dd52901874c2<2024-01-19T11:18:32.681855303Z$mixer-xsell-mixtriH206265ba-8bf0-4293-9bb0-1313b36cd66b62024-01-19T11:18:32.932576Z4mixer-packing-units-mixtriH9595a408-8b16-4160-85b0-bbe38d1c17c262024-01-19T11:18:48.247760Z.mixer-offer-badge-mixbiH13a79d73-7561-468d-983b-8ef60274d28a62024-01-19T11:25:56.200557Z.mixer-offer-badge-mixbiHc2ef3914-5599-406d-923a-3a36f56b7696(7×cLoffer(A36489161).publish_ends_extendedIVA02IGIC92(2022-01-16T07:33:33Z +19591001A012833462520001001VPR +es_ESVPRCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001012800119591 &includeAsWebNovelty +es_ESNovedadDVD"2020-01-08T23:00Z2128001195919 Verdes +es_ES Verdes Verdes +es_ES Verdes*Antara / Verde Bosque +es_ES*Antara / Verde Bosque34255158090*Antara / Verde Bosque +es_ES*Antara / Verde Bosque1(2020-01-10T10:26:54Z +es_ESSOFA 2,5PL27 +es_ESVPR274981090VPR395ML +es_ESml +0.0002401753451787$000000000149592981MUESTRARIO +es_ES*Antara / Verde Bosque +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202010/09/00112800119591____5__225x225.jpg2401753451787123707056EL CORTE INGLES +es_ES El Corte Inglés +es_ES(Personaliza tu sofá999.35882987013 +es_ES(Personaliza tu sofá +1.000 +es_ES.Sofás_nueva jerarquía999.35882986013 +es_ES Sofás +5.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN +es_ES0Sofás tapizados_NO VALE999.12743202013 +es_ES Sofás tapizados +9.000 +es_ESFSofás Salón Comedor - NO UTILIZAR999.52968013 +es_ES Sofás +6.000 +es_ESMuebles999.52958013 +es_ESMuebles +4.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNNN +es_ES$Sofás de 3 plazas999.36491523013 +es_ES$Sofás de 3 plazas +8.000 +es_ES.Sofás_nueva jerarquía999.35882986013 +es_ES Sofás +5.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN!2401753444390240175345072824017534455572401753482552240175349064924017534452672401753454757240175345642324017534815552401753442440240175344858924017534435392401753491059240175345254824017534838872401753454566240175347633924017534706892401753483610240175349262924017534537982401753479453240175346272124017534891862401753444307240175347338324017534802202401753467238240175345427624017534714402401753445076240175345699724017534782962401753454085240175348287324017534664602401753471679240175345718524017534800912401753448985240175346060424017534522582401753465128240175345623224017534785792401753486833240175348594224017534727202401753466170240175345321724017534796682401753472430240175348379524017534552352401753487984240175347049824017534833442401753462431240175345978324017534718602401753485379240175347936124017534914172401753488455240175348861524017534612742401753453590240175347224924017534897592401753478012240175345892224017534850652401753450247240175345206724017534530262401753456904240175348180724017534510152401753465319240175348406824017534644592401753480664240175346886024017534461342401753447667240175346742924017534813952401753465692240175345350724017534826992401753491738240175347976724017534805032401753470405240175347754124017534708702401753483443240175346214124017534799102401753460079240175347310924017534468992401753451770240175348168524017534487942401753442143240175349048924017534555322401753481074240175348610924017534497532401753460697240175344257024017534697372401753488868240175348496924017534909082401753485782240175345004924017534677192401753486376240175344488824017534463252401753491226240175349004524017534710682401753487403240175348433424017534699282401753461854240175348944524017534773502401753486260240175347395624017534583422401753484785240175349351024017534473772401753447858240175345921924017534778242401753486994240175349335024017534903282401753444017240175345494824017534878782401753485218240175346464024017534871132401753451206240175345805224017534679002401753493039240175347810424017534735742401753485539240175347376524017534669412401753487564240175347205824017534784562401753477701240175348667324017534458472401753476926240175347674224017534609872401753463681240175348460024017534466152401753456614240175344680624017534679932401753491981240175345129924017534831602401753466750240175347876024017534899192401753455723240175345273924017534809472401753476568240175347725124017534691572401753420455240175348871424017534685702401753463018240175346416924017534877242401753484518240175347906424017534918372401753465609240175348959924017534428602401753481968240175344824424017534712592401753480824240175348034324017534770602401753485669240175348244624017534702142401753489322240175346588324017534901752401753459509240175348813424017534764692401753492469240175348902524017534430582401753459592240175344382924017534445982401753479156240175348420424017534495622401753487243240175348212524017534923082401753461564240175346339124017534491732401753481234240175345776524017534602842401753457475240175347885224017534729112401753464831240175345053724017534921482401753490762240175344334824017534694472401753455945240175348228624017534927352401753491578240175346397124017534931902401753488295240175345158924017534633082401753483016240175347319224017534928722401753493640240175344718624017534586322401753468280240177821615624017782158902401778215203240177821549424017782150362401778214831240177821533324017782157532401778214640240177821629324017534476812401753447391240175345275324017534714642401753453040240175347660524017534918992401753477848240175344787224017534515102401753488769240175347814224017534890492401753448268240175347080124017534772752401753448916240175348408224017534799342401753492803240175348381824017534569282401753463032240175344288424017534722632401753453231240175345778924017534845322401753453521240175345952324017534586562401753476360240175347331424017534777562401753488318240175348758824017534724542401753481005240175348011424017534796822401753454207240175348669724017534517012401753455969240175345026124017534868572401753480275240175346216524017534704292401753457116240175347888324017534557472401753483511240175346009324017534858292401753462455240175345555624017534495862401753490823240175348173924017534892092401753420479240175349159224017534923222401753450070240175346274524017534468202401753471273240175349035924017534674432401753445090240175346466424017534592332401753466194240175346610124017534780362401753456447240175346120524017534843582401753473789240175348498324017534512202401753481869240175347859324017534735052401753478500240175346725224017534881652401753482712240175345749924017534716932401753451794240175346447324017534815792401753489612240175346562324017534933742401753480398240175347756524017534905022401753469461240175346821124017534471172401753446158240175345103924017534463492401753486284240175346994224017534697512401753449777240175347293524017534926432401753454290240175348701424017534618782401753488059240175344730824017534421672401753443362240175346361224017534806882401753476995240175346062824017534888822401753480534240175349125724017534448192401753487427240175348555324017534831842401753478319240175348111124017534859662401753446639240175347878424017534764832401753464855240175346390224017534853932401753490236240175348480824017534688842401753463322240175348790824017534450072401753442594240175345208124017534739702401753488639240175349097724017534653332401753477404240175346773324017534767802401753468501240175344557124017534819992401753466484240175348465524017534851332401753489506240175347188424017534824602401753491431240175348774824017534540162401753449104240175347359824017534814182401753489360240175346696524017534487252401753488479240175346091824017534547712401753482309240175349248324017534720722401753456638240175346399524017534589462401753444512240175345807624017534525622401753482620240175348717524017534435532401753490663240175348214924017534864442401753466774240175344307224017534812582401753450742240175349321324017534615882401753489773240175345055124017534829032401753443843240175344432124017534936952401753477084240175346581424017534537122401753472744240175345458024017534929262401753492162240175348993324017534552592401753483092240175345836624017534597142401753452272240175348727424017534651422401753445861240175348363424017534562562401753442495240175347108224017534791702401753461298240175349353424017534852492401753464183240175347908824017534452812401753480848240175349009024017534549622401753460406240175348336824017534685942401753444031240175347947724017534702382401753484266240175348612324017534857132401753460000240175347312324017534679242401753470610240175348391724017534708942401753479828240175349110324017534917522401753479385240175345740624017534930602401753469171240175349201824017534491972401778215234240177821506724017782159752401778215791240177821617024017782163232401778214862240177821536424017782155792401778214718240175348645124017534569352401753450759240175347939224017534435602401753458953240175347664324017534843722401753469188240175346188524017534857202401753466972240175346448024017534641902401753492650240175348320724017534600172401753489056240175347100624017534916082401753480435240175347786224017534445292401753471099240175346150224017534702452401753454788240175348263724017534574132401753478180240175348515724017534661182401753482316240175348273624017534443382401753481586240175347128024017534731302401753492339240175345402324017534805412401753493091240175346121224017534814252401753490830240175344217424017534911412401753484990240175348731124017534440482401753460635240175348200224017534571232401753483375240175348190624017534893772401753493381240175348820224017534502782401753486130240175346563024017534433792401753477107240175345209824017534537292401753463629240175346467124017534859802401753446356240175349218624017534621722401753447315240175345324824017534455882401753479699240175349296424017534870212401753459240240175348586724017534854092401753477572240175344664624017534604132401753479941240175348116624017534609252401753455976240175345353824017534679312401753487434240175346515924017534914482401753483641240175346851824017534772822401753488806240175349205624017534905192401753482927240175347208924017534739872401753456645240175346745024017534924902401753472751240175345837324017534774422401753481746240175349281024017534697682401753443850240175348481524017534852632401753465340240175346774024017534783262401753491769240175349354124017534791942401753468891240175344911124017534428912401753447698240175344482624017534879152401753486703240175345008724017534658212401753448275240175348963624017534733212401753489780240175347294224017534886462401753469478240175345056824017534718912401753459721240175346880824017534557542401753483825240175346020824017534510462401753452579240175344892324017534768032401753473796240175346995924017534889052401753445205240175347638424017534672692401753491929240175348127224017534627522401753457703240175348427324017534639192401753490670240175344616524017534522892401753466781240175344978424017534706272401753480121240175348921624017534821562401753493237240175348629124017534495932401753480282240175345626324017534708182401753455563240175348247724017534430892401753445878240175344501424017534794912401753483559240175349126424017534704362401753462462240175346333924017534641072401753455273240175345305724017534895372401753447124240175348775524017534564542401753473703240175348848624017534517182401753488325240175347889024017534615952401753420486240175347246124017534722702401753458083240175347180824017534630492401753479859240175347147124017534586632401753464862240175348759524017534428082401753483931240175346822824017534901062401753452760240175348556024017534899402401753481012240175347776324017534495002401753476490240175345123724017534515272401753479095240175348686424017534845492401753447605240175344683724017534664082401753454214240175347351224017534577962401753487182240175344251824017534902672401753493701240175348807324017534840992401753454979240175348085524017534780432401753480695240175348310824017534785172401753490373240175347860924017534520052401753448732240175346649124017534478892401753478791240175348469324017534452982401753454597240175349099124017534770082401753459530240175345450424017782161942401778215371240177821472524017782158072401778215593240177821605724017782163472401778214893240177821510424017782152412401753458090240175345528024017534932442401753490687240175346852524017534515342401753478807240175344970824017534797052401753493558240175348792224017534733382401753478623240175348672724017534929882401753491936240175346411424017534922092401753447896240175348311524017534476122401753485003240175348264424017534893842401753462769240175348275024017534817532401753489797240175347940824017534811802401753473147240175346727624017534562702401753454030240175347129724017534624792401753466798240175347044324017534699662401753447322240175347805024017534858982401753443003240175349234624017534527772401753446172240175344386724017534857372401753467467240175347996524017534778792401753452203240175347833324017534458852401753451053240175349371824017534791012401753473710240175347101324017534682352401753443577240175347986624017534702522401753487601240175348703824017534854232401753464879240175344874924017534902742401753485164240175345325524017534727682401753486468240175348881324017534910042401753484389240175348232324017534768272401753460642240175347759624017534694852401753477114240175348834924017534901132401753459738240175345057524017534609322401753484730240175347852424017534724782401753450766240175348102924017534904102401753483832240175348614724017534512442401753489957240175344550224017534892232401753471815240175345373624017534661252401753486307240175346021524017534204932401753452586240175346218924017534792002401753444345240175348293424017534569422401753457130240175345954724017534836652401753454795240175344828224017534644972401753492094240175348029924017534853002401753469195240175345306424017534559832401753489650240175346977524017534886532401753447803240175347209624017534535452401753484556240175345646124017534520122401753445021240175344281524017534801382401753487762240175344665324017534636362401753470825240175345498624017534688152401753466705240175348410524017534763912401753445595240175348321424017534777702401753492667240175346794824017534889122401753488493240175348398624017534545112401753448930240175348954424017534860002401753482033240175347890624017534691022401753477299240175347823424017534495172401753442181240175346189224017534739942401753483382240175346334624017534658382401753451725240175345896024017534917762401753446844240175346002424017534604372401753467757240175348045924017534880802401753452296240175347120424017534463632401753444055240175346180924017534555702401753465647240175348428024017534669892401753466415240175347390124017534502852401753483566240175348719924017534574202401753482163240175348143224017534644042401753461519240175344338624017534908472401753486871240175347669824017534874582401753480701240175349314524017534914622401753443096240175344912824017534925062401753456652240175347749724017534425252401753477015240175344521224017534583802401753484822240175348128924017534905332401753485577240175346392624017534547022401753471495240175346122924017534913182401753458007240175345422124017534646882401753489063240175347063424017534916152401753444536240175348058924017534729592401753472287240175348248424017534873592401753480862240175347650624017534630562401753481593240175345925724017534471312401753457710240175345577824017534586702401753491172240175345009424017534933982401753444833240175347352924017534653572401753472003240175346516624017534795072401753449791240175348191324017534928272401753488240240177821608824017782154252401778215814240177821636124017782156092401778214763240177821526524017782149302401778215128240177821623124017534502922401753443584240175348119724017534823302401753491363240175348176024017534729662401753454993240175347987324017534694922401753443874240175347683424017534562872401753482187240175345423824017534806262401753478531240175346335324017534540472401753483849240175345326224017534428222401753478067240175346248624017534577272401753481326240175348265124017534855842401753457437240175348882024017534583042401753487939240175344971524017534890872401753484839240175346219624017534861612401753471020240175345868724017534883702401753447148240175345558724017534860482401753464121240175344733924017534901202401753487625240175347670424017534564782401753473536240175348103624017534667122401753489551240175344820624017534440622401753467283240175347789324017534906942401753479118240175345529724017534870452401753493725240175347121124017534549002401753488257240175349028124017534771452401753480145240175348969824017534720102401753467474240175349267424017534831222401753461816240175349236024017534606592401753477602240175348590424017534898032401753477022240175346488624017534664222401753462776240175347864724017534886602401753492834240175349147924017534425322401753458397240175344580924017534885092401753489964240175346699624017534621032401753467955240175346469524017534592642401753493152240175346776424017534797122401753487779240175348939124017534651732401753484563240175349178324017534502092401753471822240175346123624017534782582401753492247240175345077324017534737272401753485447240175347248524017534794152401753483573240175345259324017534487562401753446370240175347778724017534803052401753492100240175347140224017534773052401753469973240175344339324017534478102401753470641240175348688824017534547192401753478944240175348160924017534864752401753484297240175346393324017534455192401753465654240175347924824017534691192401753485171240175344330024017534775032401753448503240175347334524017534840202401753483238240175348072524017534708322401753464411240175347315424017534530712401753455785240175348574424017534722942401753490441240175345221024017534450382401753466903240175346584524017534559902401753482491240175344210524017534661322401753476414240175347881424017534829412401753486734240175345695924017534515412401753463063240175349162224017534799722401753491189240175349341124017534740072401753482071240175346460224017534836722401753480466240175347026924017534697822401753472775240175346094924017534783402401753491011240175344618924017534566692401753453743240175344666024017534925132401753487496240175345202924017534819202401753445229240175344913524017534844022401753451060240175347161724017534527842401753487366240175346853224017534495242401753493282240175348631424017534443522401753463643240175345250024017534722012401753454528240175348339924017534739182401753448947240175347651324017534448402401753491943240175346536424017534571472401753443010240175348411224017534694092401753468822240175349085424017534600312401753450582240175345000124017534814492401753446851240175348720524017534445432401753484747240175348087924017534682422401753458014240175348896724017534602222401753459745240175345173224017534604512401753479545240175345125124017534421982401753485010240175348279824017534892302401753485331240175347045024017534929952401753493565240175344589224017534905572401753447629240175345897724017534880972401753459554240175345355224017534615262401778215449240177821561624017782163922401778215272240177821513524017782160952401778215821240177821478724017782149542401778216255240175348502724017534786852401753490861240175349057124017534491422401753453088240175346672924017534458162401753477794240175346566124017534797292401753456294240175346912624017534795832401753456676240175347836424017534902982401753453569240175348403724017534644282401753476858240175345550124017534677712401753483580240175348000824017534510772401753448527240175348209524017534497222401753447155240175345203624017534770392401753471631240175347221824017534776402401753461533240175348867724017534798802401753472973240175348737324017534773122401753454245240175346307024017534819372401753446677240175348940724017534606662401753485348240175348982724017534704672401753480152240175345174924017534583112401753473734240175347335224017534829582401753481203240175347392524017534648002401753444369240175346394024017534804732401753442839240175347652024017534879462401753488417240175348136424017534495312401753493732240175346748124017534651802401753464619240175344523624017534720272401753459271240175345222724017534779472401753489971240175344895424017534425492401753444857240175345715424017534917902401753489728240175345279124017534540542401753450506240175345802124017534421122401753493008240175347751024017534922782401753446103240175344876324017534838562401753450216240175348412924017534792862401753487052240175347122824017534669102401753469799240175349268124017534826682401753482354240175348444024017534430272401753469980240175348485324017534664392401753478074240175348518824017534473462401753445045240175347642124017534577342401753445526240175347854824017534910282401753469416240175348763224017534810432401753456201240175347141924017534907002401753483283240175349253724017534803122401753451558240175346095624017534923912401753472492240175344456724017534837022401753470849240175348063324017534817772401753460048240175346336024017534875332401753462783240175348146324017534872122401753459561240175347065824017534602392401753491516240175348591124017534860792401753456485240175345270824017534831392401753451268240175346365024017534500182401753458694240175345696624017534834052401753471839240175348648224017534545352401753471037240175344240224017534435082401753461823240175348852324017534682592401753486178240175346124324017534771832401753443317240175347899924017534532792401753454726240175348956824017534438812401753486901240175347316124017534586012401753464893240175345491724017534788212401753453750240175344407924017534782652401753462400240175348883724017534919502401753484754240175345251724017534461962401753467290240175348161624017534688392401753480732240175345744424017534822172401753491387240175348924724017534641382401753491646240175344638724017534624932401753443591240175348430324017534661492401753493572240175346585224017534791252401753487786240175348632124017534855912401753467207240175344821324017534911962401753490458240175345559424017534702762401753484570240175346047524017534857512401753482842240175348910024017534767112401753479422240175348088624017534589842401753493169240175345975224017534921172401753455204240175346537124017534724092401753493329240175344763624017534740142401753488998240175348548524017534507802401753488103240175346796224017534735432401753486789240175346854924017534901372401753493435240175346970624017534505992401753488264240175348250724017534621102401753446868240175347278224017534928412401753455792240175344782724017782156302401778216262240177821583824017782147942401778214985240177821545624017782164462401778216118240177821528924017782151422401753479323240175345223424017534510842401753457161240175346025324017534559142401753472225240175344408624017534489612401753478555240175349301524017534564922401753492438240175346721424017534828592401753463667240175348236124017534875402401753488530240175348692524017534894142401753486819240175347752724017534718462401753488271240175347780024017534609632401753446394240175344687524017534817842401753478081240175348137124017534853552401753485195240175347336924017534740212401753479033240175348780924017534890012401753445243240175347165524017534641452401753454924240175348341224017534495482401753449159240175344973924017534706652401753450513240175345079724017534648172401753489858240175349103524017534517562401753473178240175349014424017534857682401753481050240175348551524017534463012401753480640240175345976924017534466842401753490878240175344437624017534856142401753465197240175347085624017534627902401753461830240175346443524017534800462401753466446240175348431024017534502232401753487229240175345928824017534425562401753485928240175349155424017534661562401753444864240175345425224017534580382401753473932240175346586924017534500252401753486499240175348487724017534928582401753476728240175344877024017534621272401753465678240175347047424017534904652401753471426240175346884624017534651042401753489995240175348476124017534532862401753468556240175348225524017534779852401753444574240175347686524017534829722401753493336240175348414324017534421292401753477329240175348738024017534682662401753457451240175349254424017534935962401753459578240175348149424017534918062401753461540240175345890824017534697132401753493749240175345774124017534794392401753493480240175346067324017534727992401753492124240175349228524017534520432401753453002240175344241924017534535762401753480329240175344735324017534630872401753491394240175348868424017534821012401753458618240175347270624017534796202401753477237240175345156524017534540612401753454542240175345252424017534600552401753489261240175347973624017534812102401753469133240175346797924017534458232401753477046240175348374024017534735502401753481944240175344854124017534627072401753482675240175348633824017534912022401753487069240175349317624017534765372401753466927240175348251424017534737412401753467788240175346942324017534926982401753484587240175345551824017534783712401753483863240175348332024017534710442401753490304240175344611024017534438982401753460482240175344284624017534547332401753467498240175346673624017534876702401753489735240175344822024017534891482401753479897240175349165324017534552112401753483597240175346462624017534537672401753445533240175347241624017534807702401753463377240175348811024017534527152401753484044240175347203424017534564092401753456218240175347765724017534879532401753469904240175345070424017534433242401753451275240175348448824017534801762401753469997240175348621524017534589912401753465388240175348314624017534624172401753467405240175347872224017534816302401753489575240175349196724017534764452401753461250240175347827224017534450522401753455709240175344380524017534639572401753443515240175344716224017534478342401753480893240175348048024017534430342401753447643240175348884424017534905882401753458328240175347123524017534530952401753490717240175347298024017534788382401753485034240175348608624017534566832401753470283240175345697324017534791322401753488431240177821480024017782151662401778216279240177821564724017782154632401778215302240177821501224017782158452401778216125240177821647724017534731852401753465302240175348049724017534602772401753452722240175347166224017534791492401753478005240175348378824017534797432401753492711240175344506924017534438122401753450230240175345109124017534894212401753453774240175346155724017534577582401753465395240175348154824017534825382401753492452240175348195124017534644422401753491691240175349213124017534646332401753491400240175348562124017534849212401753469911240175345003224017534895822401753491219240175345571624017534873972401753465685240175344304124017534679862401753470481240175349061824017534915612401753487083240175347223224017534487872401753477664240175348635224017534510082401753489285240175345455924017534682732401753447360240175344669124017534782892401753452241240175345176324017534845942401753444871240175345669024017534674122401753482279240175344256324017534845012401753454931240175345052024017534667432401753486826240175348755724017534936022401753478098240175349000724017534600622401753449166240175348164724017534935032401753450711240175348268224017534476502401753467221240175349334324017534677022401753472904240175347299724017534937562401753491813240175345329324017534520502401753462424240175347733624017534677952401753468563240175349031124017534778172401753479354240175347724424017534784182401753490885240175348650524017534841502401753473949240175348901824017534838702401753482408240175347645224017534714332401753478562240175345301924017534661632401753444383240175345717824017534702902401753447179240175346367424017534583352401753488127240175347020724017534768892401753445540240175347403824017534630942401753488691240175345128224017534852012401753476735240175348106724017534727132401753477053240175348796024017534552282401753473567240175345474024017534478412401753483153240175349286524017534869702401753491974240175348179124017534706722401753479903240175347905724017534788452401753444581240175348065724017534813882401753465111240175346693424017534882882401753492292240175344955524017534592952401753479446240175348917924017534724232401753480084240175348536224017534907312401753487717240175348477824017534765442401753488578240175345698024017534641522401753465876240175348122724017534694302401753448565240175344400024017534621342401753455938240175348018324017534697202401753463384240175344612724017534850412401753443522240175348593524017534468822401753485522240175347375824017534535832401753457468240175349258224017534555252401753485775240175348844824017534489782401753480817240175344243324017534691402401753456607240175345977624017534712422401753461267240175348211824017534452502401753472041240175345407824017534708632401753458915240175346645324017534433312401753480336240175345320024017534482372401753451572240175346271424017534564162401753461847240175344213624017534775342401753446608240175347965124017534648242401753458045240175347185324017534828662401753471051240175348342924017534787532401753445830240175348360324017534829892401753452531240175346396424017534630012401753480916240175349104224017534463182401753483337240175348885124017534606802401753486093240175345920224017534595852401753487236240175349015124017534931832401753444093240175348432724017534497462401753458625240175346097024017534898962401753484051240175346885324017534878302401753460499240175348974224017534562252401753473376240175349302224017534904722401753454269240175348625324017534428532401778215029240177821547024017782148242401778216507240177821586924017782153192401778215173240177821568524017782161492401778216286A36489156A36489166A36489171A36489176A36489181A36489186A36489191A3648919627 +es_ESVPR274981090VPR395A36489161 +es_ES(Personaliza tu sofá999.35882987013 +es_ES(Personaliza tu sofá +1.000 +es_ES.Sofás_nueva jerarquía999.35882986013 +es_ES Sofás +5.000 +es_ES +Hogar999.51647013 +es_ES +HogarNNN5124401600338152 +es_ES6MOBEL YECLA TAPIZADOS, S.L.bCALLE TEJERAS,S/N-30510 YECLA - MURCIA (ESPAñA)  +es_ESfSofá tapizado de 2,5 plazas Luton El Corte Inglés +es_ESEl sofá Luton es la representación del confort. Un diseño tradicional, con respaldos y asientos rectos, para dar firmeza a la sentada, y reposabrazos en forma de almohadón para permitirte aprovechar esa parte del sofá si lo que te gusta es recostarte por completo.De formas cuadradas, robustas, este sofá te resultará resistente y duradero, además de permitirte darle un uso diario. Muy combinable en diferentes ambientes, puede integrarlo en una decoración más clásica o en espacios contemporáneos.pDisfruta de las dos plazas XL que te ofrece este modelo. +pt_PTO sofá Luton é a representação do conforto. Um design tradicional, com costas e assentos rectos, para dar firmeza ao assento, e apoios para braços em forma de almofada para lhe permitir aproveitar essa parte do sofá se o que gosta é recostar-se por completo.De formas quadradas, robustas, este sofá é resistente e duradouro, também pode ser usado diariamente. Combina bem com diferentes ambientes, pode integrá-lo numa decoração mais clássica ou em espaços contemporâneos.pDesfrute dos dois lugares XL oferecidos por este modelo.A364891615124401600338152 +es_ES6MOBEL YECLA TAPIZADOS, S.L.bCALLE TEJERAS,S/N-30510 YECLA - MURCIA (ESPAñA) 998.00209 +es_ESMuebles998.00206 +es_ES +Hogar998 +es_ES@Jerarquía de Ficha de Productos +colorLUTON380 +es_ESfSofá tapizado de 2,5 plazas Luton El Corte Inglés +es_ESfSofá tapizado de 2,5 plazas Luton El Corte Inglés +es_ESMuestrario233776090Muestrario +es_ESMuestrario +10107 +es_ESEl sofá Luton es la representación del confort. Un diseño tradicional, con respaldos y asientos rectos, para dar firmeza a la sentada, y reposabrazos en forma de almohadón para permitirte aprovechar esa parte del sofá si lo que te gusta es recostarte por completo.De formas cuadradas, robustas, este sofá te resultará resistente y duradero, además de permitirte darle un uso diario. Muy combinable en diferentes ambientes, puede integrarlo en una decoración más clásica o en espacios contemporáneos.pDisfruta de las dos plazas XL que te ofrece este modelo. +pt_PTO sofá Luton é a representação do conforto. Um design tradicional, com costas e assentos rectos, para dar firmeza ao assento, e apoios para braços em forma de almofada para lhe permitir aproveitar essa parte do sofá se o que gosta é recostar-se por completo.De formas quadradas, robustas, este sofá é resistente e duradouro, também pode ser usado diariamente. Combina bem com diferentes ambientes, pode integrá-lo numa decoração mais clássica ou em espaços contemporâneos.pDesfrute dos dois lugares XL oferecidos por este modelo. calificacion1CDcalificacion2Ecalificacion3Bcalificacion4VVcalificacion5ADcalificacion6EE06$WITHDRAWAL_SERVICEpler4twpwa2rdqpg2vhuoamrluxipaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-03T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-06T05:18:58.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02020-07-25T22:00:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE$ONEa4v6ww5dsrrike ENTITY{"identifier":"NO","name":[{"value":"NO","locale":"es_ES"}],"external_identifier":"21516242090","description":[{"value":"NO","locale":"es_ES"}],"type_lookup":"2564"}MANYabvdbs2rdyeoxoCOMPLEX {"alyalisglnj6pk":{"identifier":"Estructura","name":[{"value":"Estructura","locale":"es_ES"}],"external_identifier":"234707090","description":[{"value":"Estructura","locale":"es_ES"},{"value":"Estrutura","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":1,"amw3djmoazi23q":[{"arlfkckof3nhrq":100.0,"amifyxm5h4vona":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a5kkuujbfaypya":{"identifier":"Madera de pino y aglomerado","name":[{"value":"Madera de pino y aglomerado","locale":"es_ES"}],"external_identifier":"7594726090","description":[{"value":"Legno di pino e conglomerato","locale":"it_IT"},{"value":"Pine wood and particleboard","locale":"en_GB"},{"value":"Madera de pino y aglomerado","locale":"es_ES"},{"value":"Bois de pin et aggloméré","locale":"fr_FR"},{"value":"Madeira de pinho e aglomerado","locale":"pt_PT"}],"type_lookup":"194"}}]} @NULL@{"alyalisglnj6pk":{"identifier":"Patas","name":[{"value":"Patas","locale":"es_ES"}],"external_identifier":"234714090","description":[{"value":"Patas","locale":"es_ES"},{"value":"Pés","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":4,"amw3djmoazi23q":[{"arlfkckof3nhrq":100.0,"amifyxm5h4vona":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a5kkuujbfaypya":{"identifier":"Madera de Haya","name":[{"value":"Madera de Haya","locale":"es_ES"}],"external_identifier":"372319090","description":[{"value":"Legno di Faggio","locale":"it_IT"},{"value":"Beech wood","locale":"en_GB"},{"value":"Madera de Haya","locale":"es_ES"},{"value":"Bois de Hêtre","locale":"fr_FR"},{"value":"Madeira de faia","locale":"pt_PT"}],"type_lookup":"194"}}]}{"alyalisglnj6pk":{"identifier":"Asiento","name":[{"value":"Asiento","locale":"es_ES"}],"external_identifier":"234688090","description":[{"value":"Asiento","locale":"es_ES"},{"value":"Assento","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":2}{"alyalisglnj6pk":{"identifier":"Respaldo","name":[{"value":"Respaldo","locale":"es_ES"}],"external_identifier":"234725090","description":[{"value":"Respaldo","locale":"es_ES"},{"value":"Costas","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":2}{"alyalisglnj6pk":{"identifier":"Reposabrazos","name":[{"value":"Reposabrazos","locale":"es_ES"}],"external_identifier":"234724090","description":[{"value":"Reposabrazos","locale":"es_ES"},{"value":"Braços","locale":"pt_PT"}],"type_lookup":"10076"},"a6t6uzs6aul2i4":2,"amw3djmoazi23q":[{"arlfkckof3nhrq":100.0,"amifyxm5h4vona":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a5kkuujbfaypya":{"identifier":"Poliuretano recubierto de fibra","name":[{"value":"Poliuretano recubierto de fibra","locale":"es_ES"}],"external_identifier":"480900090","description":[{"value":"Poliuretano ricoperto di fibra","locale":"it_IT"},{"value":"Fibre-coated polyurethane","locale":"en_GB"},{"value":"Poliuretano recubierto de fibra","locale":"es_ES"},{"value":"Polyuréthanne recouvert de fibre","locale":"fr_FR"},{"value":"Poliuretano com cobertura de fibra","locale":"pt_PT"}],"type_lookup":"194"}}]}ONEaenyfxjcnnqhd2 ENTITY{"identifier":"Sofás de 3 plazas","name":[{"value":"Sofás de 3 plazas","locale":"es_ES"}],"external_identifier":"235097090","description":[{"value":"Sofás de 3 plazas","locale":"es_ES"}],"type_lookup":"10042"}ONEagusnbyzvvsh7u NUMBER77MANYagv3lrjucyrexmCOMPLEX{"abmqasrofr6ncu":{"identifier":"No","name":[{"value":"No","locale":"es_ES"}],"external_identifier":"347406090","description":[{"value":"No","locale":"en_GB"},{"value":"No","locale":"es_ES"},{"value":"Non","locale":"fr_FR"},{"value":"Não","locale":"pt_PT"}],"type_lookup":"144"}}ONEagxzafqhy5pkgg NUMBER94MANYaiowsh755gtziu STRING[{"locale":"es_ES","value":["Este producto es personalizado y no admite devolución."]}]ONEakzzyg4snb6u42 ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}ONEalih4mlm2oj5qy NUMBER196MANYall7jshlgswax4 STRING[{"locale":"es_ES","value":["Por favor, asegúrese de que todos los accesos al domicilio tienen las medidas necesarias para la entrega de la mercancía. En caso de ser necesario desmontaje y montaje del artículo, poner una grúa o cualquier otra gestión adicional requerida para poder realizar la entrega, los costes de estos servicios serán asumidos por el cliente."]}]ONEamqcbfmzbopfde ENTITY{"identifier":"3 Plazas","name":[{"value":"3 Plazas","locale":"es_ES"}],"external_identifier":"234684090","description":[{"value":"3 Plazas","locale":"es_ES"}],"type_lookup":"10102"}ONEaopyy33i6kpc3y ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}ONEar6gp3jqldrbt4 ENTITY{"identifier":"No","name":[{"value":"No","locale":"es_ES"}],"external_identifier":"347406090","description":[{"value":"No","locale":"es_ES"}],"type_lookup":"144"}ONEato6duzhihm4g4 ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}ONEatpgrmvd6q6dxy NUMBER48MANYayehwror5k5tas ENTITY{"identifier":"Tapizado","name":[{"value":"Tapizado","locale":"es_ES"}],"external_identifier":"349971090","description":[{"value":"Tapizado","locale":"es_ES"}],"type_lookup":"194"}MANYazjue4n64ntcka ENTITY{"color_code":"Verde","color_description":[{"value":"Verde","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Verde","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___11929O2.png","size":"small"}],"description":[{"value":"Verde","locale":"es_ES"}],"identifier":"11929","name":[{"value":"COLOR_VERDE","locale":"es_ES"}],"external_identifier":"597003054"},"identifier":"Verde","name":[{"value":"Verde","locale":"es_ES"}],"external_identifier":"347197090"}ONEaztnv4kkljcyro STRING Cincha elásticaMuebles_ISS.SPEC_SECONDARY_TEMPLATE +es_ESSupervoluminoso348626090Supervoluminoso +es_ESSupervoluminoso401$000000000149592981(2020-07-25T22:00:01Z(2022-10-06T05:18:58Z"2022-10-03T22:00Z$001012800119591 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore 16H795ecc36-00b5-4e46-a139-f57b232aaaec DELETE<2023-09-02T17:30:43.228115398Z4dataloader-mongo-kafka-job62023-09-02T17:31:09.351181Z(mixer-gtin-agr-kfreeH6271f1dc-7666-4829-84f6-23a31ad57b0a62023-09-02T17:32:55.420752Z,mixer-gtin-calc-pcsflmH4fa9a152-04b4-47ba-9f73-ce130efd026b62023-09-02T17:32:56.419133Z,mixer-gtin-calc-pcsflmHa90556c8-8736-4005-9e09-0279cfd804f562023-09-03T02:55:43.396282Z0mixer-product-calc-kfreeH3306ab0b-2422-4bfb-aa81-e950278ef007<2024-01-19T11:18:28.511116788Z$mixer-xsell-mixtriH94d460e3-1c81-4bcf-bcae-00dddd52eb9062024-01-19T11:18:33.045139Z4mixer-packing-units-mixtriH2e405122-9353-4c8c-b086-4ce57cc20d4e62024-01-19T11:18:48.252274Z.mixer-offer-badge-mixbiH369bb7e7-43a0-48a5-8beb-f3f1d0b3948562024-01-19T11:25:56.203880Z.mixer-offer-badge-mixbiHc04344af-a310-402b-b148-23128c4f6318(7×c,7ǻmf!Loffer(A43998307).publish_ends_extendedIVA02IGIC91 +06508001013042841298001503COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001013050306508046&includeAsWebNovelty +es_ESNovedadDVD Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2022-06-20T13:12:53Z +es_ESPANTALON158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401840381843$000001531104780046TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png24018403818438521816056ZERMATT +es_ESZermatt +es_ES"Pantalones rectos999.39090702013 +es_ES"Pantalones rectos +8.000 +es_ESPantalones999.39090691013 +es_ESPantalones 20.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43998307 +es_ES"Pantalones rectos999.39090702013 +es_ES"Pantalones rectos +8.000 +es_ESPantalones999.39090691013 +es_ESPantalones 20.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN5814121600144675 +es_ES@DECORACION ARTESANAL SOUTO, S.L.CALLE ILDEFONSO MANUEL GIL Nº 35 -1º,N-50018 ZARAGOZA - ZARAGOZA (ESPAñA)  +es_ESLPantalón de mujer liso con bolsillos +es_ESPantalón liso con goma con botón postizo con bolsillos largo tipo corsario pata ancha.A439983078521816056ZERMATT +es_ESZERMATT5814121600144675 +es_ES@DECORACION ARTESANAL SOUTO, S.L.CALLE ILDEFONSO MANUEL GIL Nº 35 -1º,N-50018 ZARAGOZA - ZARAGOZA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeT2213010 +es_ESLPantalón de mujer liso con bolsillos +es_ESLPantalón de mujer liso con bolsillos +es_ESPantalón liso con goma con botón postizo con bolsillos largo tipo corsario pata ancha. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5B00N47933909046 +es_ES46E +es_ESEspañol47933909046 +es_ES46477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-09-28T00:42:56.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-29T00:42:56.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-07-01T04:19:38.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}{"identifier":"Puede limpiarse en seco","name":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"external_identifier":"4197325090","description":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEabf2vvifj26pzi ENTITY{"identifier":"Largo","name":[{"value":"Largo","locale":"es_ES"}],"external_identifier":"2655628090","description":[{"value":"Largo","locale":"es_ES"}],"type_lookup":"2507"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pantalones rectos","name":[{"value":"Pantalones rectos","locale":"es_ES"}],"external_identifier":"2696302090","description":[{"value":"Pantalones rectos","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001531104780046(2022-07-01T04:19:38Z(2022-09-29T00:42:56Z(2022-09-28T00:42:56Z$001013050306508046001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore046Hee8dfcf7-83b4-441c-bb96-d1047df97bab DELETE<2023-09-02T17:28:24.539712813Z4dataloader-mongo-kafka-job62023-09-02T17:28:38.245048Z(mixer-gtin-agr-kfreeHfd575aa3-10e8-4a8f-a673-bfb8ab0534dd62023-09-02T17:31:05.111471Z,mixer-gtin-calc-pcsflmHb41296e2-e348-4ff1-bfe1-f104f40d220262023-09-02T17:31:05.416261Z,mixer-gtin-calc-pcsflmHaf007037-c917-4890-be29-ac893a592c3a62023-09-03T03:23:10.356410Z0mixer-product-calc-kfreeHf34cb953-c749-4633-a26a-7a7f75e40c11<2024-01-19T11:18:46.780181570Z$mixer-xsell-mixtriH0e8803f7-ed7e-4086-b777-23b9cb8c553862024-01-19T11:18:47.189204Z4mixer-packing-units-mixtriHf0acf5ea-3926-40ba-8271-2d02b518420562024-01-19T11:18:48.319983Z.mixer-offer-badge-mixbiH2d835e2a-469d-4872-9555-54c914a334a162024-01-19T11:25:56.205116Z.mixer-offer-badge-mixbiHa5480036-5eca-47cd-bc85-ed33c4122f17(7×cLoffer(A16177275).publish_ends_extendedIVA02IGIC91 +1081800100353084979001316COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001003531610818 12 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2014-06-26T19:07:43Z +es_ESCOLEGIOS156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401354590212$000001002911670012TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401354590212860167056 WINNER +es_ES Winner +es_ES"Uniformes Reserva999.39791424013 +es_ES"Uniformes Reserva 11.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A16177275 +es_ES"Uniformes Reserva999.39791424013 +es_ES"Uniformes Reserva 11.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNN4977661600152801 +es_ES8GENEROS DE PUNTO MOLLA, S.L.CALLE LG CºFUENSANTA.12.P.I.PARTIDA,..-46870 ONTINYENT - VALENCIA (ESPAñA)  +es_ES*Short vóley femenino +es_ES,Short vóley femenino.A16177275860167056KIDS ECI +es_ESKIDS ECI4977661600152801 +es_ES8GENEROS DE PUNTO MOLLA, S.L.CALLE LG CºFUENSANTA.12.P.I.PARTIDA,..-46870 ONTINYENT - VALENCIA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize4977661600152801 +es_ES8GENEROS DE PUNTO MOLLA, S.L.CALLE LG CºFUENSANTA.12.P.I.PARTIDA,..-46870 ONTINYENT - VALENCIA (ESPAñA) AULA.EXTRAESCOL +es_ES*Short vóley femenino +es_ES*Short vóley femenino +es_ES,Short vóley femenino. calificacion1A3calificacion2Acalificacion3XTcalificacion4VVcalificacion5VVcalificacion6IN0612 +es_ES12E +es_ESEspañol12 +es_ES12477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING$Quitar False TG PDONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"locale":"es_ES","value":"011"}],"external_identifier":"233768090","description":[{"locale":"es_ES","value":"Gestión Automática - Despublica publicadas sin stock ECI"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-07-31T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-23T06:28:20.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-09-26T22:00:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"locale":"es_ES","value":"Lavar máximo 30º"}],"external_identifier":"344723090","description":[{"locale":"es_ES","value":"Lavar máximo 30º"}],"type_lookup":"1584","glossary":{"identifier":"51640","name":[{"locale":"es_ES","value":"LAVARMAXTREINTA"}],"external_identifier":"599743054","term":[{"locale":"es_ES","value":"LavarMaxTreinta"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"locale":"es_ES","value":"Lavar máximo 30º"}]}}{"identifier":"No usar lejía","name":[{"locale":"es_ES","value":"No usar lejía"}],"external_identifier":"344724090","description":[{"locale":"es_ES","value":"No usar lejía"}],"type_lookup":"1584","glossary":{"identifier":"51313","name":[{"locale":"es_ES","value":"NOUSARLEJIA"}],"external_identifier":"599720054","term":[{"locale":"es_ES","value":"NoUsarLejía"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"locale":"es_ES","value":"No usar lejía."}]}} {"identifier":"Planchado max 110º","name":[{"locale":"es_ES","value":"Planchado max 110º"}],"external_identifier":"344725090","description":[{"locale":"es_ES","value":"Planchado max 110º"}],"type_lookup":"1584","glossary":{"identifier":"32851","name":[{"locale":"es_ES","value":"PLANCHADOCIENTODIEZ"}],"external_identifier":"599166054","term":[{"locale":"es_ES","value":"PlanchadoCientoDiez"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"locale":"es_ES","value":"Planchado máximo 110º"}]}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"locale":"es_ES","value":"Otoño-Invierno"}],"external_identifier":"479797090","description":[{"locale":"es_ES","value":"Otoño-Invierno"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Unisex","name":[{"locale":"es_ES","value":"Unisex"}],"external_identifier":"344788090","description":[{"locale":"es_ES","value":"Unisex"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Uniformes","name":[{"locale":"es_ES","value":"Uniformes"}],"external_identifier":"2949424090","description":[{"locale":"es_ES","value":"Uniformes"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"identifier":"Negro","name":[{"locale":"es_ES","value":"Negro"}],"external_identifier":"347149090","color_code":"Negro","color_description":[{"locale":"es_ES","value":"Negro"}],"glossary":{"identifier":"25525","name":[{"locale":"es_ES","value":"COLOR_NEGRO"}],"external_identifier":"599042054","term":[{"locale":"es_ES","value":"Color Negro"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png","size":"small"}],"description":[{"locale":"es_ES","value":"Negro"}]}}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"locale":"es_ES","value":"%"}],"external_identifier":"344726090","description":[{"locale":"en_GB","value":"%"},{"locale":"es_ES","value":"%"},{"locale":"fr_FR","value":"%"},{"locale":"pt_PT","value":"%"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"locale":"es_ES","value":"Poliéster"}],"external_identifier":"344749090","description":[{"locale":"it_IT","value":"Poliestere"},{"locale":"en_GB","value":"Polyester"},{"locale":"es_ES","value":"Poliéster"},{"locale":"fr_FR","value":"Polyester"},{"locale":"pt_PT","value":"Poliéster"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":100.0}]}]}MANYatc4u6vijhkdp6 NUMBER2014Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001002911670012(2022-09-26T22:00:01Z(2022-10-23T06:28:20Z(2022-07-31T22:00:01Z$001003531610818 12001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore 12H144d9ce6-cce5-4d53-b6cb-7eb79a05efac DELETE<2023-09-02T17:34:02.739386468Z4dataloader-mongo-kafka-job62023-09-02T17:41:44.812358Z(mixer-gtin-agr-kfreeH3b45e8ec-618c-4ee0-9cc5-790a16701c7762023-09-02T17:45:45.022555Z,mixer-gtin-calc-pcsflmH9771afa9-75ed-4d27-98f2-566acbf1364e62023-09-02T17:45:46.809843Z,mixer-gtin-calc-pcsflmHcad8fdee-5bdf-4a60-a6cf-869d1484adea62023-09-03T03:06:07.816115Z0mixer-product-calc-kfreeHbde30cf9-2aed-48a0-a071-a2fc19c1e9d7<2024-01-19T11:18:47.152488273Z$mixer-xsell-mixtriHf1552410-be07-41ae-ab5e-545625cf830062024-01-19T11:18:47.283028Z4mixer-packing-units-mixtriH8c774b37-006b-40a9-8cdc-539c092434fa62024-01-19T11:18:48.322742Z.mixer-offer-badge-mixbiH6f064f69-651d-4cf9-853d-3fc9d081038362024-01-19T11:25:56.205818Z.mixer-offer-badge-mixbiH3627e693-1b85-49c9-a8f5-ca5c47ff17f9(7×cLoffer(A27348089).publish_ends_extendedIVA02IGIC92 +13528001028626299335001350COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001028635013528 &includeAsWebNovelty +es_ESNovedadDVD"2018-07-19T22:00Z3536403346126"2018-07-19T22:00Z2286350135281 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2018-07-23T08:16:38Z +es_ES*PACK 3 MEMORIAS USB N56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003536403346126$000000000147004271TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401690241229375786056PNY +es_ESPNY +es_ESPendrives999.7624054013 +es_ESPendrives +2.000 +es_ES@Tarjetas de memoria y Pen drives999.7624045013 +es_ES@Tarjetas de memoria y Pen drives 20.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNN56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A27348089 +es_ESPendrives999.7624054013 +es_ESPendrives +2.000 +es_ES@Tarjetas de memoria y Pen drives999.7624045013 +es_ES@Tarjetas de memoria y Pen drives 20.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNN0303974 +es_ES"DMI COMPUTER S.A. +es_ESRPack 3 Pendrives PNY Neón, 32 GB USB 2.0A27348089375786056PNY +es_ESPNY0303974 +es_ES"DMI COMPUTER S.A.998.00086 +es_ESDiscos Duros998.00081 +es_ESInformática998 +es_ES@Jerarquía de Ficha de Productos +años +es_ES +años +3.000FD32GATT4N1PGRY +es_ESRPack 3 Pendrives PNY Neón, 32 GB USB 2.0(FD32GATT4N1PGRYX3-EF +es_ESRPack 3 Pendrives PNY Neón, 32 GB USB 2.0 calificacion1A1calificacion2Ecalificacion3M5calificacion4VVcalificacion5EScalificacion61N06pjej4owgwj3w3wpler4twpwa2rdqpyn6g54ac5ybuoONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRINGZDespublicar div21 web email raul chapa 150722ONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02020-09-04T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-07-14T22:00:01.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02018-07-19T22:01:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa2yownhoqwqr7s ENTITY{"identifier":"Pendrive","name":[{"value":"Pendrive","locale":"es_ES"}],"external_identifier":"19318196090","description":[{"value":"Pendrive","locale":"es_ES"}],"type_lookup":"518"}MANYa4hcef7bfxfsd4COMPLEX[{"locale":"es_ES","value":[{"adnggioympmvq6":"Compatibilidad","am263n4hgc7nmk":["Windows 2000 / XP / Vista / 7 / 8; Mac OS: 10.3 y superiores"]}]}]ONEa67z74cj564jyc ENTITY{"identifier":"GB","name":[{"value":"GB","locale":"es_ES"}],"external_identifier":"347549090","description":[{"value":"GB","locale":"es_ES"}],"type_lookup":"199","glossary":{"term":[{"value":"GB (Gigabyte)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Unidad de medida de capacidad de almacenamiento como, por ejemplo, en una memoria interna, un discos duro o una tarjeta de memoria.","locale":"es_ES"}],"identifier":"11520","name":[{"value":"GB_(GIGABYTE)","locale":"es_ES"}],"external_identifier":"596940054"}}MANYa6kmwtdvkbzhzq ENTITY{"identifier":"USB 2.0","name":[{"value":"USB 2.0","locale":"es_ES"}],"external_identifier":"348799090","description":[{"value":"USB 2.0","locale":"es_ES"}],"type_lookup":"185","glossary":{"term":[{"value":"USB 2.0","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Es un puerto que sirve para conectar periféricos a un ordenador. Tasa de transferencia de hasta 480 Mbps .","locale":"es_ES"}],"identifier":"10255","name":[{"value":"USB_2.0","locale":"es_ES"}],"external_identifier":"596764054"}}ONEacqbhti7kg5xny NUMBER32ONEagcfjw6vsmj5xs ENTITY{"identifier":"g","name":[{"value":"g","locale":"es_ES"}],"external_identifier":"347187090","description":[{"value":"g","locale":"es_ES"}],"type_lookup":"206"}ONEajauo6gj554lxi ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEakhsi4cwuz3o5i NUMBER60.0MANYalin3hdzzrag4m NUMBER1ONEan5q7s4wg4ksg6 NUMBER20.0ONEap37hkobewzjho NUMBER1ONEas77vpobmi3cy6 NUMBER20.0 Discos_Duros_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000147004271"2018-07-19T22:01Z(2022-07-14T22:00:01Z"2020-09-04T22:00Z$001028635013528 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H96de1f12-6c56-4c07-a3e0-7e48f0ef7590 DELETE<2023-09-02T17:03:38.691832589Z4dataloader-mongo-kafka-job62023-09-02T17:03:44.498546Z(mixer-gtin-agr-kfreeHfd77bfd2-1ad8-445e-a9cb-bc9b0377368262023-09-02T17:04:21.102424Z,mixer-gtin-calc-pcsflmH0a36126d-5519-470e-8f89-f33c9cc35a8762023-09-02T17:04:23.305118Z,mixer-gtin-calc-pcsflmHa4af9f17-2457-4e4c-a88f-50e00172968e62023-09-03T02:48:20.652025Z0mixer-product-calc-kfreeH36e8edc9-b551-4f99-9b52-b4c4403271b8<2024-01-19T11:18:47.114510537Z$mixer-xsell-mixtriH0cc60c05-fded-47a9-adb8-3959c284076662024-01-19T11:18:47.259381Z4mixer-packing-units-mixtriH004c305c-7e35-401d-bd24-e818e35663d562024-01-19T11:18:48.314820Z.mixer-offer-badge-mixbiHb6705af5-07f0-4c8e-a77e-76322f75dbea62024-01-19T11:25:56.207299Z.mixer-offer-badge-mixbiHa8e6c606-481b-4109-a200-c3a7704bdbc6(7×cLoffer(A32924808).publish_ends_extendedIVA02IGIC91 +24905001V009834507901001801COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001009880124905060&includeAsWebNovelty +es_ESNovedadDVDAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2020-03-05T10:54:32Z +es_ESGORRA MARINERA155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401744907392$000001492910860060TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401744907392123357056EMIDIO TUCCImarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/2/00001269352/00001269352355mM1011.jpg +es_ESEmidio Tucci +es_ES$Gorros y sombreros999.39072722013 +es_ES$Gorros y sombreros +5.000 +es_ESAccesorios999.39072257013 +es_ESAccesorios +3.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ES4hombre dias plus diciembre997.40891439011 +es_ES4hombre dias plus diciembre 20.000 +es_ES,Moda Hombre Contenedor997.37546749011 +es_ES6Moda Hombre Contenedor DiasNN +es_ES"Hombre abril dias997.38719053011 +es_ES"Hombre abril dias +7.000 +es_ES,Moda Hombre Contenedor997.37546749011 +es_ES6Moda Hombre Contenedor DiasNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A32924808 +es_ES$Gorros y sombreros999.39072722013 +es_ES$Gorros y sombreros +5.000 +es_ESAccesorios999.39072257013 +es_ESAccesorios +3.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN5053761600246991 +es_ES(GORRAS BEIRETS, S.L.lCALLE NARANJO,1-13270 ALMAGRO - CIUDAD REAL (ESPAñA)  +es_ESHGorra de hombre estilo marinera azul +es_ES`Gorra estilo marinero en color azul de algodón.A32924808123357056E. TUCCI +es_ESE. TUCCI5053761600246991 +es_ES(GORRAS BEIRETS, S.L.lCALLE NARANJO,1-13270 ALMAGRO - CIUDAD REAL (ESPAñA) 998.00194 +es_ESComplementos998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeSAILOR-ALGODÓN +es_ESHGorra de hombre estilo marinera azul +es_ESHGorra de hombre estilo marinera azul +es_ES`Gorra estilo marinero en color azul de algodón. +calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5Z10047939309060 +es_ES60E +es_ESEspañol47939309060 +es_ES60477062090Español +Tallapler4twpwa2rdqphm44qlzhmwa2ypeymj6wu3nmofgpaxawji3i4mkoqMANYa5wg3q7jlozdji ENTITY{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"}],"type_lookup":"1633"}MANYa5xfo2abga2eme NUMBER2020ONEaa72dm3yz6vb5u ENTITY{"identifier":"Gorras","name":[{"value":"Gorras","locale":"es_ES"}],"external_identifier":"2682113090","description":[{"value":"Gorras","locale":"es_ES"}],"type_lookup":"1619"}ONEanxumtnaxc7bmw ENTITY{"identifier":"Gorros y Sombreros","name":[{"value":"Gorros y Sombreros","locale":"es_ES"}],"external_identifier":"2700665090","description":[{"value":"Gorros y Sombreros","locale":"es_ES"}],"type_lookup":"1573"}MANYarbqbgl5kiiqhmCOMPLEX +{"a3gd23j3lhtuz2":[{"a5shyljk4cvjq6":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"ajxlygljz2ct42":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"},"a23xjq2h2haw5g":100.0}]}MANYaz2gbwdmqlkyim ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}MANYazrazbd5hx4qa4 ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"} Complementos_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-09-04T00:43:44.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-05T00:43:44.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-02-21T06:08:29.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001492910860060(2022-02-21T06:08:29Z(2022-09-05T00:43:44Z(2022-09-04T00:43:44Z$001009880124905060001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore060H50dfef76-aea7-499b-822f-4ed5473d5a67 DELETE<2023-09-02T17:19:11.499033185Z4dataloader-mongo-kafka-job62023-09-02T17:19:23.781721Z(mixer-gtin-agr-kfreeH8777c4ad-5ca9-4b34-a1f3-2c396b9d33dc62023-09-02T17:19:47.311784Z,mixer-gtin-calc-pcsflmH7e1ee06e-c476-4fd5-bdb1-118cfc4e647462023-09-02T17:19:50.106841Z,mixer-gtin-calc-pcsflmH0a658e89-1eaa-4f65-bdae-503813527f3562023-09-03T02:41:18.159624Z0mixer-product-calc-kfreeH995a8b1d-a3cc-4d35-9fe4-41428cdc6d72<2024-01-19T11:17:59.759941740Z$mixer-xsell-mixtriH02c9110a-3fee-4118-b719-dbd525f37ee962024-01-19T11:18:01.254346Z4mixer-packing-units-mixtriH3b18260c-41bf-4418-80d5-a7b37c440b2662024-01-19T11:18:48.621860Z.mixer-offer-badge-mixbiH1598c704-a251-46e4-9265-5fae49d942dc62024-01-19T11:25:56.208192Z.mixer-offer-badge-mixbiHaf59753d-c399-470d-9b93-942850d1ba9c(7×cIVA02IGIC91 +3778500102023-03-09T09:49:36.728Z019725984333001102COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001019710237785050&includeAsWebNovelty +es_ESNovedadDVD"2018-04-02T22:00Z3606803286275 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2018-07-05T23:01:32Z +es_ESCAMISETAS WIN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003606803286275$000001464669840050TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401677333701127457056LE COP SPORTIFmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201407/22/1320913542_1_.jpg +es_ESLe Coq Sportif +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESCamisetas999.14598525013 +es_ESCamisetas +1.000 +es_ESRopa deportiva999.12473890013 +es_ESRopa deportiva +1.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A261333175805661600134965 +es_ES>PAPELES PINTADOS CAMARASA, S.L.xCALLE HORT DE SORIANO,3-46900 TORRENTE - VALENCIA (ESPAñA)  +es_ESBCamiseta de hombre Le Coq Sportif +es_ES JCamiseta manga corta y cuello redondo:Jersey 140 g 100 % Algodón6Agradable y suave de llevar,Corte regular/clásico0Canalé 1x1 en el escotejGran 'Logo del Gallo' estampado en la parte delanteraA26133317127457056LE COQ SPORTIF +es_ESLE COQ SPORTIF5805661600134965 +es_ES>PAPELES PINTADOS CAMARASA, S.L.xCALLE HORT DE SORIANO,3-46900 TORRENTE - VALENCIA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize1820034 +es_ESBCamiseta de hombre Le Coq Sportif +es_ESBCamiseta de hombre Le Coq Sportif +es_ES JCamiseta manga corta y cuello redondo:Jersey 140 g 100 % Algodón6Agradable y suave de llevar,Corte regular/clásico0Canalé 1x1 en el escotejGran 'Logo del Gallo' estampado en la parte delantera calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5Bcalificacion6MO06479353090 +48-50 +es_ES +48-50E +es_ESEspañol479439090M +es_ESM18171618090Fabricante +Tallapler4twpwa2rdqpz3c2qg46aax5qpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-08-14T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-08-16T08:07:38.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02018-07-02T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"351059090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Negro","color_description":[{"value":"Negro","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Negro","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png","size":"small"}],"description":[{"value":"Negro","locale":"es_ES"}],"identifier":"25525","name":[{"value":"COLOR_NEGRO","locale":"es_ES"}],"external_identifier":"599042054"},"identifier":"Negro","name":[{"value":"Negro","locale":"es_ES"}],"external_identifier":"347149090"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2018Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001464669840050"2018-07-02T22:00Z(2019-08-16T08:07:38Z"2019-08-14T22:00Z$001019710237785050001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore050He2cff90b-f625-499f-957f-3ef3fdf8543e DELETE<2023-09-02T17:20:28.333394594Z4dataloader-mongo-kafka-job62023-09-02T17:20:35.917017Z(mixer-gtin-agr-kfreeH8ee34fc3-8282-46bf-ba14-fbd001a5aa3462023-09-02T17:20:37.634418Z,mixer-gtin-calc-pcsflmHec6c74d0-7ef1-4cc5-b9ba-79576905c6e162023-09-02T17:20:44.036503Z,mixer-gtin-calc-pcsflmHfd9d5d71-473b-4aa7-8b02-da27d53eee0262023-09-03T02:42:25.063284Z0mixer-product-calc-kfreeHc737737e-8cd7-481b-9056-ba18c54b9da3<2024-01-19T11:18:00.192854484Z$mixer-xsell-mixtriH379f17ae-d015-4821-ac13-93b77b65fb0062024-01-19T11:18:01.338460Z4mixer-packing-units-mixtriHbe3ac3a1-6590-482c-a598-3f4ff0fd1f8b62024-01-19T11:18:48.624943Z.mixer-offer-badge-mixbiHfd3264f3-50b9-43c0-8ba3-f97b539b3e3f62024-01-19T11:25:56.208748Z.mixer-offer-badge-mixbiH06e9d8d5-f19d-4e81-aa84-b5983512feb3(7×cLoffer(A40776874).publish_ends_extendedIVA02IGIC91 +06140001017342424595001405COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001017340506140116Multicolor +es_ESMulticolorMulticolor +es_ESMulticolorMulticolor +es_ESMulticolor352633090 +es_ESMulticolor598507054 +20205 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png +es_ES6COLOR_MULTICOLOR_SECUNDARIO +es_ES6Color Multicolor SecundarioMulticolor +es_ESMulticolor0(2022-05-11T07:09:36Z +es_ES,BAÑADOR GRECA GEOMETR156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401808433416$000001517196320116TRADICIONAL +es_ES6COLOR_MULTICOLOR_SECUNDARIO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png240180843341639212703056(KIDS EL CORTE INGLES +es_ES*Kids El Corte Inglés +es_ESBañadores999.39089406013 +es_ESBañadores +1.000 +es_ES +Baño999.39089402013 +es_ES +Baño 25.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40776874 +es_ESBañadores999.39089406013 +es_ESBañadores +1.000 +es_ES +Baño999.39089402013 +es_ES +Baño 25.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN0822759 +es_ES.HANGZHOU COFNA CO., LTD +es_ESNBañador de niña con greca geométrica +es_ESpBañador con greca geométrica con un tirante mas ancho.A4077687439212703056KIDS ECI +es_ESKIDS ECI0822759 +es_ES.HANGZHOU COFNA CO., LTD998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeCOLGRE FSW +es_ESNBañador de niña con greca geométrica +es_ESNBañador de niña con greca geométrica +es_ESpBañador con greca geométrica con un tirante mas ancho. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5VV00N47914909016 Años +es_ES16 AñosE +es_ESEspañol40414562090+14 +es_ES+1418171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING(Fuerzo Rebajas 80822ONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-21T00:53:05.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-22T00:53:05.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-05-02T22:00:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Geométrico","name":[{"value":"Geométrico","locale":"es_ES"}],"external_identifier":"25521450090","description":[{"value":"Geométrico","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bañadores","name":[{"value":"Bañadores","locale":"es_ES"}],"external_identifier":"349580090","description":[{"value":"Bañadores","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niña","name":[{"value":"Niña","locale":"es_ES"}],"external_identifier":"357131090","description":[{"value":"Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Baño","name":[{"value":"Baño","locale":"es_ES"}],"external_identifier":"349577090","description":[{"value":"Baño","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":15,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":85,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517196320116(2022-05-02T22:00:01Z(2022-09-22T00:53:05Z(2022-09-21T00:53:05Z$001017340506140116001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore116Hac1b521c-b1c9-4128-938e-73116be1069d DELETE<2023-09-02T17:24:51.378056965Z4dataloader-mongo-kafka-job62023-09-02T17:25:01.039321Z(mixer-gtin-agr-kfreeHfda5da5e-a521-436c-8d29-e80dadb89fb962023-09-02T17:26:46.411864Z,mixer-gtin-calc-pcsflmHb560ab01-297c-443a-b7bb-1bf52b4b3a0d62023-09-02T17:26:50.407957Z,mixer-gtin-calc-pcsflmHededbe3c-1551-4d40-b90d-43494f3025a562023-09-03T02:42:33.015402Z0mixer-product-calc-kfreeHb1c358d1-470f-4271-b8b3-d9fe34c0127f<2024-01-19T11:18:00.271001282Z$mixer-xsell-mixtriHc7fedc67-00b2-403a-afcb-cf7aaafd245562024-01-19T11:18:01.350100Z4mixer-packing-units-mixtriH59e5dca2-0d99-4c04-a6bb-b85e0650eab762024-01-19T11:18:48.625976Z.mixer-offer-badge-mixbiH96d2cecb-2e74-4cdc-92f4-7066c190bd1a62024-01-19T11:25:56.209338Z.mixer-offer-badge-mixbiH41e92b95-6b59-4519-b950-5ff4916df6c2(7×cIVA02IGIC91 +0659000102023-04-24T18:16:13.610Z019738926456001258COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001019725806590104 +Rojos +es_ES +Rojos +Rojos +es_ES +RojosRojo / Blanco +es_ESRojo / Blanco8257708090 +es_ESRojo / Blanco12880621054 +15145 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201607/21/15145_2_.png +es_ES&COLOR_ROJO_/_BLANCO +es_ES&Color Rojo / BlancoRojo / Blanco +es_ESRojo / Blanco0(2021-05-05T10:08:58Z +es_ESPANTALON LARGO +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401796451133$000001512829700104TRADICIONAL +es_ES&COLOR_ROJO_/_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201607/21/15145_2_.png2401796451133123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas + +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESPantalones999.14632330013 +es_ESPantalones +4.000 +es_ESRopa deportiva999.14566788013 +es_ESRopa deportiva +1.000 +es_ES Niños999.12406167013 +es_ES Niños +4.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESLDeportes - Contenedor 2as rebajas pv22997.43004735011 +es_ES6contenedor 2as rebajas pv22N +es_ESDeportes997.42247120011 +es_ESDeportes 16.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESDDeportes - Contenedor Rebajas PV22997.42771890011 +es_ES@contenedor rebajas deportes pv22N +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A396028645788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ESbPantalón de niños Adicolor SST adidas Originals +es_ESpLa interacción atemporal entre lo clásico y lo modernoLuce un estilo retro arrollador con este pantalón adidas para jóvenes exploradores urbanos. El trébol bordado y las 3 bandas le confieren un toque deportivo atemporal. Su tejido de punto brillante completa el look. Este producto se ha confeccionado con Primeblue, un tejido reciclado de alto rendimiento creado con Parley Ocean Plastic.PrimeblueCorte clásico:Cintura elástica con cordón>Punto 100% poliéster reciclado Tejido brillanteDBolsillos frontales con cremallera"Puños de canalé +en_GBGo all-in on throwback style. Rock a legit adidas vibe in these juniors' track pants. An embroidered Trefoil logo and 3-Stripes keep your OG style on point. That signature sheen of tricot adds the finishing touch. These pants are made with Primeblue, a high-performance recycled material made in part with Parley Ocean Plastic.PrimeblueRegular fit2Drawcord on elastic waistShiny fabric"Front zip pocketsRibbed cuffs +pt_PTlA interação intemporal entre o clássico e o modernoPrimeblue Tecido brilhanteA39602864123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize H37871 +es_ESbPantalón de niños Adicolor SST adidas Originals +es_ESbPantalón de niños Adicolor SST adidas Originals +es_ESTradicional233777090Tradicional +es_ESTradicional +10107 +es_ESpLa interacción atemporal entre lo clásico y lo modernoLuce un estilo retro arrollador con este pantalón adidas para jóvenes exploradores urbanos. El trébol bordado y las 3 bandas le confieren un toque deportivo atemporal. Su tejido de punto brillante completa el look. Este producto se ha confeccionado con Primeblue, un tejido reciclado de alto rendimiento creado con Parley Ocean Plastic.PrimeblueCorte clásico:Cintura elástica con cordón>Punto 100% poliéster reciclado Tejido brillanteDBolsillos frontales con cremallera"Puños de canalé +en_GBGo all-in on throwback style. Rock a legit adidas vibe in these juniors' track pants. An embroidered Trefoil logo and 3-Stripes keep your OG style on point. That signature sheen of tricot adds the finishing touch. These pants are made with Primeblue, a high-performance recycled material made in part with Parley Ocean Plastic.PrimeblueRegular fit2Drawcord on elastic waistShiny fabric"Front zip pocketsRibbed cuffs +pt_PTlA interação intemporal entre o clássico e o modernoPrimeblue Tecido brilhante calificacion1Acalificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO06N19970930903-4 Años +es_ES3-4 AñosE +es_ESEspañol1165209090 104 cm +es_ES 104 cm18171618090Fabricante +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-05-02T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-05-03T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-05-02T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Niños","name":[{"value":"Niños","locale":"es_ES"}],"external_identifier":"349990090","description":[{"value":"Niños","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347622090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001512829700104"2021-05-02T22:00ZDVD"2021-05-03T22:00Z"2021-05-02T22:00Z$001019725806590104001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore104H6acaf041-f9de-4d36-be00-cab60c6719c0 DELETE<2023-09-02T17:35:57.512908414Z4dataloader-mongo-kafka-job62023-09-02T17:47:12.872364Z(mixer-gtin-agr-kfreeHe82eba24-7aef-4501-baaa-93ab39afd05662023-09-02T17:58:05.162366Z,mixer-gtin-calc-pcsflmH4e589334-9515-40c3-9b8f-2105feb85f7b62023-09-02T17:58:15.230663Z,mixer-gtin-calc-pcsflmH499ff532-419e-424a-a3e7-2a85568f56f062023-09-03T03:09:23.938474Z0mixer-product-calc-kfreeH84745290-32fd-4ffb-b0f3-ae03ed43616c<2024-01-19T11:18:47.367219775Z$mixer-xsell-mixtriH2fe3aae4-9a18-4ceb-afc8-59e93c48ffa262024-01-19T11:18:47.568850Z4mixer-packing-units-mixtriH6e9e83b4-2153-45e0-97bb-c12ada2d17c062024-01-19T11:18:48.637412Z.mixer-offer-badge-mixbiH8c424ec8-a3fb-4ff1-b209-84f841fdc8f162024-01-19T11:25:56.210506Z.mixer-offer-badge-mixbiH9ad5d571-99d9-42a5-8fbf-a643a7fd99b0(7×cIVA02IGIC91 +0697700102023-04-25T00:02:47.670Z032442861440001253COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001032425306977092"2021-11-17T23:00Z4065429287247 +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa +es_ESRosa347700090 +es_ESRosa5985060542019 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png +es_ESCOLOR_ROSA +es_ESColor RosaRosa +es_ESRosa0(2022-06-21T15:24:57Z +es_ESI LIN FT JOG +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004065429287247$000001521447520092TRADICIONAL +es_ESCOLOR_ROSA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png2401817458776123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas +es_ESChándals999.14779372013 +es_ESChándals +6.000 +es_ESRopa deportiva999.14566791013 +es_ESRopa deportiva +1.000 +es_ES +Bebé999.12406168013 +es_ES +Bebé +5.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESChándals999.53670013 +es_ESChándals +9.000 +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A417444715788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ESHChándal de bebés Essentials adidas +en_GB^A comfy sweatshirt and pants combo for infants. To an infant, every moment is a new experience. Keep them wrapped in cosy comfort as they explore the world around them in this sweatshirt and pants combo. It slips on easily with a snug fit that stays in place. The chest graphic and adidas Badge of Sport add style and future-athlete vibes.Our cotton products support sustainable cotton farming. This is part of our ambition to end plastic waste.Regular fitZSweatshirt: Ribbed crewneck with snap buttons@Sweatshirt: Ribbed cuffs and hem(Pants: Elastic waist +fr_FRzUn ensemble sweat-shirt et pantalon confortable pour bébés. Pour bébé, chaque moment est une nouvelle expérience. Cet ensemble sweat-shirt et pantalon l'enveloppe de confort quand il explore le monde qui l'entoure. Il s'enfile facilement et reste bien en place grâce à sa coupe ajustée. Le graphisme sur la poitrine et le logo adidas Badge of Sport ajoutent une touche stylée et sport pour le futur athlète.Nos produits en coton soutiennent une culture durable, dans le cadre de notre lutte contre les déchets plastiques.Coupe standard.Sweat-shirt : encolure ras-du-cou côtelée avec boutons-pression.TSweat-shirt : Base et poignets côtelés.Cross - Contenedor Noches Flash997.40995448011 +es_ES.Contenedor Noches FlashCDNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43896156 +es_ES*Sudaderas con capucha999.39089875013 +es_ES*Sudaderas con capucha +1.000 +es_ES*Sudaderas y Chándals999.39072579013 +es_ES*Sudaderas y Chándals +5.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNNN6212151600502534 +es_ES>BESTSELLER WHOLESALE SPAIN,S.L.fCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA)  +es_ES$Sudadera de hombre +es_ESSudadera de hombre con capucha y print en la parte frontal. Tejido de confort y suavidad.A43896156212432056JACK&JONES +es_ESJACK&JONES6212151600502534 +es_ESTBESTSELLER WHOLESALE SPAIN,S.L._recargaNFTfCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize12215379 +es_ES$Sudadera de hombre +es_ES$Sudadera de hombre +es_ESSudadera de hombre con capucha y print en la parte frontal. Tejido de confort y suavidad. calificacion1Acalificacion2Acalificacion3RIcalificacion4VVcalificacion5AAcalificacion62200N4791760902 +es_ES2E +es_ESEspañol479443090S +es_ESS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02023-03-01T18:44:52.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-06-23T06:28:10.000ZONEate3liesiuooycBOOLEAN +falseONEafabpb3cbt6g3oTIMESTAMP02023-03-02T18:44:52.000ZONEakzd7vzeui6lmu STRINGDFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}{"identifier":"Puede limpiarse en seco","name":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"external_identifier":"4197325090","description":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Capucha","name":[{"value":"Capucha","locale":"es_ES"}],"external_identifier":"31942201090","description":[{"value":"Capucha","locale":"es_ES"}],"type_lookup":"1595"}ONEac5swxsdtmjapu ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"347714090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1617"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Sport","name":[{"value":"Sport","locale":"es_ES"}],"external_identifier":"347623090","description":[{"value":"Sport","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sudaderas y chándals","name":[{"value":"Sudaderas y chándals","locale":"es_ES"}],"external_identifier":"2739751090","description":[{"value":"Sudaderas y chándals","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"},{"value":"Algodão","locale":"pt_PT"},{"value":"Coton","locale":"fr_FR"},{"value":"Cotton","locale":"en_GB"},{"value":"Cotone","locale":"it_IT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":70.0},{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliéster","locale":"es_ES"},{"value":"Poliéster","locale":"pt_PT"},{"value":"Polyester","locale":"fr_FR"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliestere","locale":"it_IT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":30.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001530630370002(2022-06-23T06:28:10ZDVD(2023-03-02T18:44:52Z(2023-03-01T18:44:52Z$001012260220376002001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore002Ha30a8fdb-d698-4577-9d75-c01bfb9736e0 DELETE.62023-08-09T21:53:54.921030Z2catalog-offersmergerd-agrH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-08-09T21:53:55.539687Z&catalog-offer-mixbiH5c851831-4166-4e9a-88c8-6c0af5e11f3a<2023-08-09T21:53:55.796483394Z2catalog-item-goodtype-pcsH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-08-09T21:53:56.209832Z catalog-gtin-pstH5c851831-4166-4e9a-88c8-6c0af5e11f3a<2023-08-09T21:53:56.333967855Z2catalog-previous-gtin-pcsH5c851831-4166-4e9a-88c8-6c0af5e11f3a<2023-08-10T02:05:41.617915922Z*catalog-schools-mixbiH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-08-10T02:05:42.198757Z*site-calculator-mixbiH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-08-10T02:05:42.202721Z*site-calculator-mixbiH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-08-10T02:05:42.683647Z8site-canonical-overrides-pcsH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-08-10T02:05:42.992758Z2site-product-interval-pcsH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T18:44:16.433353Zsite-eventingH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T18:44:19.081106Z8site-canonical-emitter-kfreeH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T18:44:20.042150Z0site-pack-components-agrH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T18:44:20.042168Z0site-pack-components-agrH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T18:44:21.015401Z4mixer-canonical-map-filterH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T19:42:28.316935Z(mixer-gtin-agr-kfreeH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T21:20:44.315830Z,mixer-gtin-calc-pcsflmH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-02T21:20:45.127129Z,mixer-gtin-calc-pcsflmH5c851831-4166-4e9a-88c8-6c0af5e11f3a62023-09-03T03:07:08.108971Z0mixer-product-calc-kfreeH5c851831-4166-4e9a-88c8-6c0af5e11f3a<2024-01-19T11:18:48.157597880Z$mixer-xsell-mixtriH5c851831-4166-4e9a-88c8-6c0af5e11f3a62024-01-19T11:18:48.218872Z4mixer-packing-units-mixtriH5c851831-4166-4e9a-88c8-6c0af5e11f3a62024-01-19T11:18:48.916411Z.mixer-offer-badge-mixbiHd6448535-f173-44bd-a8c3-5d4b9539744662024-01-19T11:25:56.289873Z.mixer-offer-badge-mixbiH5c851831-4166-4e9a-88c8-6c0af5e11f3a(΀7ر×c,7ǻmf! Loffer(A42641969).publish_ends_extendedIVA02IGIC91 +02844001046341473458001611COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001046361102844002&includeAsWebNovelty +es_ESNovedadDVD"2022-01-30T23:00Z4064819586465Blancos +es_ESBlancosBlancos +es_ESBlancos +Crudo +es_ES +Crudo353271090 +es_ES +Crudo599789054 +52735 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___52735O1.png +es_ESCOLOR_CRUDO +es_ESColor Crudo +Crudo +es_ES +Crudo0(2022-01-31T13:03:48Z +es_ES +LINEN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004064819586465$000001525161380002TRADICIONAL +es_ESCOLOR_CRUDO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___52735O1.png2401826881442384225056"ESPRIT COLLECTION +es_ES"Esprit Collection +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42641969 +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN5811051600140400 +es_ESCARAMBA, S.L.CALLE AV CABECICOS BLANCOS.PARC.15-2,BZ25-30892 LIBRILLA - MURCIA (ESPAñA)  +es_ESEmisión y canje BF excepciones997.40662154011 +es_ES>Emisión y canje BF excepciones 19.000 +es_ES2Moda_Zapatos_Informativas997.33067667011 +es_ES2Moda_Zapatos_InformativasCDN +es_ESVAC emisión997.37254410011 +es_ESVAC emisión +8.000 +es_ES2Moda_Zapatos_Informativas997.33067667011 +es_ES2Moda_Zapatos_InformativasCDN +es_ES"Moda del 24 al 25997.44306187011 +es_ES"Moda del 24 al 25 19.000 +es_ESXCross - Contenedor 2022 BF Resto categorías997.44305668011 +es_ES(BF Resto categoríasCDN +es_ES8Excepciones Tarifa plana VAC997.42783817011 +es_ES8Excepciones Tarifa plana VAC 23.000 +es_ES2Moda_Zapatos_Informativas997.33067667011 +es_ES2Moda_Zapatos_InformativasCDN +es_ES$Zapatos de colegio997.35437860011 +es_ES$Zapatos de colegio +6.000 +es_ES2Moda_Zapatos_Informativas997.33067667011 +es_ES2Moda_Zapatos_InformativasCDN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A26221069 +es_ES.Bailarinas y merceditas999.39073075013 +es_ES.Bailarinas y merceditas +3.000 +es_ESZapatos niña999.39072680013 +es_ESZapatos niña +3.000 +es_ESZapatos999.39072679013 +es_ESZapatos +5.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN5825421600158873 +es_ES:CERAMICAS GALLEGO-BONET, S.L.lCALLE GERMANIAS,11-46940 MANISES - VALENCIA (ESPAñA)  +es_ESNMerceditas de niña Winner de piel azul +es_ESMerceditas de piel en color azul marino, con cierre de tira adherente y puntera redonda.A26221069860167056 WINNER +es_ES WINNER5825421600158873 +es_ES:CERAMICAS GALLEGO-BONET, S.L.lCALLE GERMANIAS,11-46940 MANISES - VALENCIA (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize5825421600158873 +es_ES:CERAMICAS GALLEGO-BONET, S.L.lCALLE GERMANIAS,11-46940 MANISES - VALENCIA (ESPAñA) 433 +es_ESNMerceditas de niña Winner de piel azul433 +es_ESNMerceditas de niña Winner de piel azul +es_ESMerceditas de piel en color azul marino, con cierre de tira adherente y puntera redonda. calificacion1A3calificacion2Acalificacion3ROcalificacion4VVcalificacion5Bcalificacion6CL0030 +es_ES30E +es_ESEspañol30 +es_ES30477062090Español +Tallapler4twpwa2rdqpwe2kceprh5w3aONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRING.Publicar calif agotadorONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"locale":"es_ES","value":"011"}],"external_identifier":"233768090","description":[{"locale":"es_ES","value":"Gestión Automática - Despublica publicadas sin stock ECI"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-03T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-08T04:48:13.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02020-07-11T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa7jpc7s7go77wi ENTITY{"identifier":"Otros materiales","name":[{"locale":"es_ES","value":"Otros materiales"}],"external_identifier":"349472090","description":[{"locale":"es_ES","value":"Otros materiales"}],"type_lookup":"1633"}ONEa7xqyqnqtfqof6 ENTITY{"identifier":"Merceditas","name":[{"locale":"es_ES","value":"Merceditas"}],"external_identifier":"357130090","description":[{"locale":"es_ES","value":"Merceditas"}],"type_lookup":"1620"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Caucho","name":[{"locale":"es_ES","value":"Caucho"}],"external_identifier":"349460090","description":[{"locale":"es_ES","value":"Caucho"}],"type_lookup":"1633"}ONEalnwwhqri3drmq ENTITY{"identifier":"Cierre adherente","name":[{"locale":"es_ES","value":"Cierre adherente"}],"external_identifier":"37335489090","description":[{"locale":"es_ES","value":"Cierre adherente"}],"type_lookup":"1574"}MANYamzex7cmn57eei ENTITY{"identifier":"Niña","name":[{"locale":"es_ES","value":"Niña"}],"external_identifier":"357131090","description":[{"locale":"es_ES","value":"Niña"}],"type_lookup":"1575"}MANYaqmgzyppu6mney ENTITY{"identifier":"Piel vacuna","name":[{"locale":"es_ES","value":"Piel vacuna"}],"external_identifier":"347772090","description":[{"locale":"es_ES","value":"Piel vacuna"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Otoño-Invierno","name":[{"locale":"es_ES","value":"Otoño-Invierno"}],"external_identifier":"479797090","description":[{"locale":"es_ES","value":"Otoño-Invierno"}],"type_lookup":"1577"}ONEauik4rxccjjcze ENTITY{"identifier":"Redonda","name":[{"locale":"es_ES","value":"Redonda"}],"external_identifier":"3020307090","description":[{"locale":"es_ES","value":"Redonda"}],"type_lookup":"1612"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Merceditas","name":[{"locale":"es_ES","value":"Merceditas"}],"external_identifier":"357130090","description":[{"locale":"es_ES","value":"Merceditas"}],"type_lookup":"1620"}ONEauur46vhpycka4 ENTITY{"identifier":"Zapatos niña","name":[{"locale":"es_ES","value":"Zapatos niña"}],"external_identifier":"357129090","description":[{"locale":"es_ES","value":"Zapatos niña"}],"type_lookup":"1611"}MANYav5dyt5c6cep6g ENTITY{"identifier":"Azul","name":[{"locale":"es_ES","value":"Azul"}],"external_identifier":"347189090","color_code":"Azul","color_description":[{"locale":"es_ES","value":"Azul"}],"glossary":{"identifier":"15915","name":[{"locale":"es_ES","value":"COLOR_AZUL"}],"external_identifier":"598455054","term":[{"locale":"es_ES","value":"Color Azul"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png","size":"small"}],"description":[{"locale":"es_ES","value":"Azul"}]}}MANYaxr5m2ljibnmui NUMBER2018MANYaysizsllntmwzgCOMPLEX {"ahx7en5mskblj4":{"identifier":"Plantilla","name":[{"locale":"es_ES","value":"Plantilla"}],"external_identifier":"10765251090","description":[{"locale":"en_GB","value":"Insole"},{"locale":"es_ES","value":"Plantilla"},{"locale":"fr_FR","value":"Semelle intérieure"},{"locale":"pt_PT","value":"Palmilha"}],"type_lookup":"1576"},"abjlulhwauqmm2":[{"aed5i4gt3gvp5u":{"identifier":"Otros materiales","name":[{"locale":"es_ES","value":"Otros materiales"}],"external_identifier":"349472090","description":[{"locale":"it_IT","value":"Altri materiali"},{"locale":"en_GB","value":"Other materials"},{"locale":"es_ES","value":"Otros materiales"},{"locale":"fr_FR","value":"Autres matériaux"},{"locale":"pt_PT","value":"Outros materiais"}],"type_lookup":"1633"}}]} {"abjlulhwauqmm2":[{"aed5i4gt3gvp5u":{"identifier":"Otros materiales","name":[{"locale":"es_ES","value":"Otros materiales"}],"external_identifier":"349472090","description":[{"locale":"it_IT","value":"Altri materiali"},{"locale":"en_GB","value":"Other materials"},{"locale":"es_ES","value":"Otros materiales"},{"locale":"fr_FR","value":"Autres matériaux"},{"locale":"pt_PT","value":"Outros materiais"}],"type_lookup":"1633"}}],"ahx7en5mskblj4":{"identifier":"Forro","name":[{"locale":"es_ES","value":"Forro"}],"external_identifier":"477728090","description":[{"locale":"en_GB","value":"Lining"},{"locale":"es_ES","value":"Forro"},{"locale":"fr_FR","value":"Doublure"},{"locale":"pt_PT","value":"Forro"}],"type_lookup":"1576"}}Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001465059820030"2020-07-11T22:00Z(2022-10-08T04:48:13Z"2022-10-03T22:00Z$001001333100103030001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore030H8d85038c-b747-445b-aeb9-a924945faa50 DELETE<2023-09-02T17:31:24.915495225Z4dataloader-mongo-kafka-job62023-09-02T17:36:22.015683Z(mixer-gtin-agr-kfreeH2ce54f55-c825-4083-b8ef-10639323de7062023-09-02T17:47:03.906166Z,mixer-gtin-calc-pcsflmH4283e1ec-97d3-47c3-aee6-28767b88f6b362023-09-02T17:47:17.007412Z,mixer-gtin-calc-pcsflmH07db3a84-2c53-4dfb-af14-d002e52b8ff062023-09-02T22:43:04.939253Z0mixer-product-calc-kfreeHaba08faa-df53-4055-9b09-edc88417cebc<2024-01-19T11:18:49.724575156Z$mixer-xsell-mixtriHfd058751-669a-4556-8400-f3900730a09862024-01-19T11:18:49.788568Z4mixer-packing-units-mixtriH3c68f796-fdcd-4025-b0e5-aa4a083571e262024-01-19T11:18:49.981920Z.mixer-offer-badge-mixbiH0ec84bf7-e6e2-4357-a24e-841bfb84bf7562024-01-19T11:25:56.294171Z.mixer-offer-badge-mixbiHcbed6207-df23-48bc-acb5-b5f66759849e(ր7ر×cIVA02IGIC92 +1003600102023-04-24T23:55:59.745Z028537723753001148COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001028514810036  +es_ES8Restricción Reacondicionado161226080908Restricción Reacondicionado +es_ES8Restricción ReacondicionadoSPECIAL_GOOD +es_ESInternet1229735090Internet +es_ESInternet(2023-01-24T03:08:56ZDVD +Plata +es_ES +Plata +Plata +es_ES +Plata +Plata +es_ES +Plata344764090 +es_ES +Plata596743054 +10148 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20110223/___10148O2.png +es_ESCOLOR_PLATA +es_ESColor Plata +Plata +es_ES +Plata0(2020-12-28T14:11:54Z +es_ES*QLED 55" QE55Q80TAT 4B +es_ESB13175914090 +es_ESENERGY_LABEL_B43235388054 +91341 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202208/01/00191341_1__100x100.jpg +es_ES*ETIQUETA_ENERGETICA_B +es_ES,ETIQUETA ENERGÉTICA BB +11001 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401784581088$000000000150853227TRADICIONAL +es_ESCOLOR_PLATA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20110223/___10148O2.png2401784581088122381056Samsung +es_ESSamsung +es_ESTV y Vídeo999.19641840013 +es_ESTV y Vídeo +1.000 +es_ESDReacondicionados - Imagen y Sonido999.19641839013 +es_ESTV y Sonido +2.000 +es_ES>Reacondicionados - Electrónica999.19641834013 +es_ES Reacondicionados 97.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNNNB +es_ESB13175914090 +es_ESENERGY_LABEL_B43235388054 +91341 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202208/01/00191341_1__100x100.jpg +es_ES*ETIQUETA_ENERGETICA_B +es_ES,ETIQUETA ENERGÉTICA BB +11001 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A383910775047831600239061 +es_ES:SAMSUNG ELECTRONICS IBERIA SACALLE AV DE LA TRANSICIÓN ESPAÑOLA,32-28108 ALCOBENDAS - MADRID (ESPAñA)  +es_ESTV QLED 138 cm (55") Samsung QE55Q80T con Inteligencia Artificial 4K, HDR 1500 y Smart TV (Reacondicionado casi a estrenar) +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características100% Volumen de color: Únicos TVs capaces de reproducir el 100% del volumen de color a cualquier nivel de brillo gracias a la tecnología inorgánica Quantum dot. 16 bits color mapping.Direct Full Array 1500: Con un brillo de hasta 1500 nits, QLED controla la iluminación trasera analizando escena por escena y mejora el contraste añadiendo profundidad en los detalles. Mejora los colores en cada escena.Q Symphony"Asistentes de vozA38391077122381056SAMSUNG +es_ESSAMSUNG5047831600239061 +es_ESPSAMSUNG ELECTRONICS IBERIA SA_recargaNFTCALLE AV DE LA TRANSICIÓN ESPAÑOLA,32-28108 ALCOBENDAS - MADRID (ESPAñA) 998.00059 +es_ESTV plana998.00118 +es_ESElectrónica998 +es_ES@Jerarquía de Ficha de Productos +años +es_ES +años +3.000VPD35QE55Q80TAT +es_ESTV QLED 138 cm (55") Samsung QE55Q80T con Inteligencia Artificial 4K, HDR 1500 y Smart TV (Reacondicionado casi a estrenar)QE55Q80TATXXC +es_ESTV QLED 138 cm (55") Samsung QE55Q80T con Inteligencia Artificial 4K, HDR 1500 y Smart TV (Reacondicionado casi a estrenar) +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características100% Volumen de color: Únicos TVs capaces de reproducir el 100% del volumen de color a cualquier nivel de brillo gracias a la tecnología inorgánica Quantum dot. 16 bits color mapping.Direct Full Array 1500: Con un brillo de hasta 1500 nits, QLED controla la iluminación trasera analizando escena por escena y mejora el contraste añadiendo profundidad en los detalles. Mejora los colores en cada escena.Q Symphony"Asistentes de voz calificacion1Acalificacion2Rcalificacion3E5calificacion4VVcalificacion5EScalificacion61100p35ozgvi2yffsqpler4twpwa2rdqLMANYa2pgedyericr6c ENTITY{"identifier":"Eco Sensor","name":[{"value":"Eco Sensor","locale":"es_ES"}],"external_identifier":"122086090","description":[{"value":"Eco Sensor","locale":"es_ES"}],"type_lookup":"10142"}ONEa3cvqzztgp4raq ENTITY{"identifier":"QLED","name":[{"value":"QLED","locale":"es_ES"}],"external_identifier":"18389401090","description":[{"value":"QLED","locale":"es_ES"}],"type_lookup":"188"}MANYa3xehaq7xaqfl4 STRING[{"locale":"es_ES","value":["Inteligencia Artificial 4K: Samsung aplica la más revolucionaria y pionera tecnología de Inteligencia Artificial para transformar y mejorar la calidad de sonido e imagen, independientemente de la fuente de origen."]}]ONEa3zov3mikqsss4 ENTITY{"identifier":"SI","name":[{"value":"SI","locale":"es_ES"}],"external_identifier":"21516241090","description":[{"value":"SI","locale":"es_ES"}],"type_lookup":"2564"}MANYa4zgwd32opndfm ENTITY {"identifier":"HDMI","name":[{"value":"HDMI","locale":"es_ES"}],"external_identifier":"347409090","description":[{"value":"HDMI","locale":"es_ES"}],"type_lookup":"185","glossary":{"term":[{"value":"HDMI","locale":"es_ES"}],"media_objects":[],"description":[{"value":"High Definition Multimedia Interface (HDMI) es un tipo de conexión diseñado para transmitir contenido de audio y vídeo digital de alta calidad. Mejora la experiencia cinematográfica para reproducir lo último en películas, juegos y música con una calidad de sonido e imagen asombrosa que inundará todo el salón de casa. Sólo necesita un cable de alta velocidad para conectar los dispositivos de alta definición","locale":"es_ES"}],"identifier":"11725","name":[{"value":"HDMI","locale":"es_ES"}],"external_identifier":"596975054"}}{"identifier":"USB","name":[{"value":"USB","locale":"es_ES"}],"external_identifier":"347408090","description":[{"value":"USB","locale":"es_ES"}],"type_lookup":"185","glossary":{"term":[{"value":"USB (Universal Serial Bus)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Puerto que permite conectar periféricos como una llave USB, un lector MP3, una cámara de fotos digital, etc. El USB 3.0 es la nueva versión ultrarrápida del interfaz USB. Norma para un nuevo bus (o comunicación) externo compatible con velocidades de transferencia de datos de 12 Mbps. Se prevé que USB sustituya completamente los puertos en serie y paralelo. Adicionalmente, USB resulta especialmente adecuado para la descarga directa a alta velocidad de imágenes, tan pronto como se realiza la conexión, entre una cámara digital y un ordenador.","locale":"es_ES"}],"identifier":"10415","name":[{"value":"USB_(UNIVERSAL_SERIAL_BUS)","locale":"es_ES"}],"external_identifier":"596787054"}}{"identifier":"Audio digital","name":[{"value":"Audio digital","locale":"es_ES"}],"external_identifier":"364823090","description":[{"value":"Audio digital","locale":"es_ES"}],"type_lookup":"185"}{"identifier":"Common Interface","name":[{"value":"Common Interface","locale":"es_ES"}],"external_identifier":"350248090","description":[{"value":"Common Interface","locale":"es_ES"}],"type_lookup":"185"}{"identifier":"Radiofrecuencia","name":[{"value":"Radiofrecuencia","locale":"es_ES"}],"external_identifier":"354449090","description":[{"value":"Radiofrecuencia","locale":"es_ES"}],"type_lookup":"185"}{"identifier":"RS-232C","name":[{"value":"RS-232C","locale":"es_ES"}],"external_identifier":"12001900090","description":[{"value":"RS-232C","locale":"es_ES"}],"type_lookup":"185"}MANYa6mhc7c7uamgda ENTITY{"identifier":"Wi-Fi","name":[{"value":"Wi-Fi","locale":"es_ES"}],"external_identifier":"350839090","description":[{"value":"Wi-Fi","locale":"es_ES"}],"type_lookup":"10139"}ONEa74mqzqssqm7jq ENTITY{"identifier":"PQI","name":[{"value":"PQI","locale":"es_ES"}],"external_identifier":"20344867090","description":[{"value":"PQI","locale":"es_ES"}],"type_lookup":"10144"}ONEabjbwfnavuakps ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}ONEac7aen2leus4cq NUMBER138ONEadg5yzldtdamns NUMBER57.4ONEadl3f7k4e5wndo NUMBER 3800.0MANYaeb2ooy3ve6kp6 NUMBER 421111ONEafe2kskbdwkdjg NUMBER 1230.1MANYafubenua4rvkge ENTITY{"identifier":"200x200","name":[{"value":"200x200","locale":"es_ES"}],"external_identifier":"12880837090","description":[{"value":"200x200","locale":"es_ES"}],"type_lookup":"197"}ONEag2fx5bwfahwpa ENTITY{"identifier":"SI","name":[{"value":"SI","locale":"es_ES"}],"external_identifier":"12936473090","description":[{"value":"SI","locale":"es_ES"}],"type_lookup":"10140"}ONEagbc73es2fgvdc NUMBER793ONEahhikqxu2pjdyi ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}ONEahwnwhfglcqsp6 ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"220859090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"10138"}MANYai2pu4ztowvogu ENTITY{"identifier":"HDTV (Sintonizador TDT de Alta Definición)","name":[{"value":"HDTV (Sintonizador TDT de Alta Definición)","locale":"es_ES"}],"external_identifier":"350240090","description":[{"value":"HDTV (Sintonizador TDT de Alta Definición)","locale":"es_ES"}],"type_lookup":"191"}ONEai3ew3rkbfmu7y NUMBER +340.4ONEaiccyxg2ejfbfa ENTITY{"identifier":"\"","name":[{"value":"\"","locale":"es_ES"}],"external_identifier":"347404090","description":[{"value":"\"","locale":"es_ES"}],"type_lookup":"204"}MANYaifcpafaeio36k ENTITY {"identifier":"UHD 4K","name":[{"value":"UHD 4K","locale":"es_ES"}],"external_identifier":"153679090","description":[{"value":"UHD 4K","locale":"es_ES"}],"type_lookup":"158","glossary":{"term":[{"value":"UHD 4K","locale":"es_ES"}],"media_objects":[],"description":[{"value":"UHD 4K es un nuevo sistema de TV que tiene una resolución de 3840x2160 pixeles, que es 4 veces mayor que la actual HD (dos veces mayor que Full HD). \nTambién se conoce por ''Quad HD, UDTV, ó UHDTV''(Ultra high definition television). UHD 4K ofrece una calidad de detalle de imagen fantástica y permite visualizar pantallas más grandes con más calidad, sin percibir ninguna estructura de píxeles visible.","locale":"es_ES"}],"identifier":"3706","name":[{"value":"UHD_4K","locale":"es_ES"}],"external_identifier":"2352461054"}}ONEaig3pvqjrzjgta NUMBER16.2ONEajb74mcgs5ay76 NUMBER 3840.0ONEalyfad2oqkwhro ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}ONEaofnqbw2parydk NUMBER18.4ONEaoh6wrzkfjfluk ENTITY{"identifier":"16:9","name":[{"value":"16:9","locale":"es_ES"}],"external_identifier":"350236090","description":[{"value":"16:9","locale":"es_ES"}],"type_lookup":"149"}ONEaorz2mqkljhqnu NUMBER0.5ONEaozdeqqirqg33m NUMBER 1230.1ONEapmukphrih7k2s ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEaqty6cmnqv4sry NUMBER55MANYaryp27zt65sb6w STRING[{"locale":"es_ES","value":["Disney+","Netflix","Rakuten TV","HBO","Youtube","DAZN","Universal Guide","SmartThings"]}]ONEasm5upwaremo6w NUMBER +705.9ONEasyddwatzvyygg ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEattlfulq2e2auq ENTITY{"identifier":"Hz","name":[{"value":"Hz","locale":"es_ES"}],"external_identifier":"348644090","description":[{"value":"Hz","locale":"es_ES"}],"type_lookup":"202"}ONEavclr7w4ck2zd2 NUMBER 2160.0ONEawfynbfol6ywla ENTITY{"identifier":"W","name":[{"value":"W","locale":"es_ES"}],"external_identifier":"350678090","description":[{"value":"W","locale":"es_ES"}],"type_lookup":"201"}ONEaylix33oltl5h6 ENTITY{"identifier":"p","name":[{"value":"p","locale":"es_ES"}],"external_identifier":"2999725090","description":[{"value":"p","locale":"es_ES"}],"type_lookup":"209"}TV_Plana_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02021-01-10T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-01-11T23:00:00.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEANtrueMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}ONEazravcn5thdy6eTIMESTAMP02020-12-29T09:07:45.000ZMANYaqundqcyqbyf5mTIMESTAMP02023-01-24T03:08:56.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESSupervoluminoso348626090Supervoluminoso +es_ESSupervoluminoso401$000000000150853227DVD"2021-01-11T23:00Z"2021-01-10T23:00Z +es_ESA estrenar32681224090A estrenar +es_ESA estrenar2643090$001028514810036 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hb05032e5-1b43-4d20-b267-53c9b671c2f4 DELETE<2023-09-02T17:36:26.427523103Z4dataloader-mongo-kafka-job62023-09-02T17:41:41.210223Z(mixer-gtin-agr-kfreeH05cc5148-063e-458e-ba0a-a3195990f63862023-09-02T17:53:59.105679Z,mixer-gtin-calc-pcsflmH921de878-bd1e-409d-b00f-e4ea812bc8ff62023-09-02T17:53:59.406451Z,mixer-gtin-calc-pcsflmH725d60e7-daf4-482e-b483-39133c5b922162023-09-02T22:50:30.943792Z0mixer-product-calc-kfreeH489a2666-f43e-480f-a44a-41e888a60ea7<2024-01-19T11:18:33.828129952Z$mixer-xsell-mixtriHf35d6571-36e2-411f-82be-0478362a843662024-01-19T11:18:34.117083Z4mixer-packing-units-mixtriH3c40c59a-3983-40df-95af-f887ac544bf262024-01-19T11:18:50.003536Z.mixer-offer-badge-mixbiHfe75f803-4e7e-4ab9-8e3e-daec82ef55f062024-01-19T11:25:56.294761Z.mixer-offer-badge-mixbiH9483d59d-c4ba-49f0-af07-3a66bbe5dbaf(؀7ر×cLoffer(A41781337).publish_ends_extendedIVA02IGIC91 +04679001054240808999001800COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001054280004679040&includeAsWebNovelty +es_ESNovedadDVD"2021-11-21T23:00Z0755406586572 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2021-11-24T16:26:16Z +es_ESVESTIDOS158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000755406586572$000001521606780040TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png240181781925636221601056DKNY JEANS +es_ESDkny Jeans +es_ESVestidos999.39090719013 +es_ESVestidos 14.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41781337 +es_ESVestidos999.39090719013 +es_ESVestidos 14.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0905121 +es_ES4G III LEATHER FASHIONS INC +es_ES^Vestido corto con cuello redondo y manga larga. +es_ESVestido corto in animalia con cuello pico, manga larga y cinturon elastico.A4178133736221601056DKNY JEANS +es_ESDKNY JEANS12459981600905121 +es_ES4G III LEATHER FASHIONS INCfCALLE 512 7TH AVENUE 35 TH,.- NY - (PAISES BAJOS) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeE2CMXHVS +es_ES^Vestido corto con cuello redondo y manga larga. +es_ES^Vestido corto con cuello redondo y manga larga. +es_ESVestido corto in animalia con cuello pico, manga larga y cinturon elastico. +calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5BPDN47930109040 +es_ES40E +es_ESEspañol479437090L +es_ESL18171618090Fabricante +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-30T04:23:03.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-06-02T10:46:51.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Animal Print","name":[{"value":"Animal Print","locale":"es_ES"}],"external_identifier":"9338932090","description":[{"value":"Animal Print","locale":"es_ES"}],"type_lookup":"2504"}ONEabf2vvifj26pzi ENTITY{"identifier":"Corto","name":[{"value":"Corto","locale":"es_ES"}],"external_identifier":"2655626090","description":[{"value":"Corto","locale":"es_ES"}],"type_lookup":"2507"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYagio3trrjaqhgg ENTITY{"identifier":"Tela","name":[{"value":"Tela","locale":"es_ES"}],"external_identifier":"477974090","description":[{"value":"Tela","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Vestidos","name":[{"value":"Vestidos","locale":"es_ES"}],"external_identifier":"344732090","description":[{"value":"Vestidos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":48,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Modal","name":[{"value":"Modal","locale":"es_ES"}],"external_identifier":"347876090","description":[{"value":"Modal","locale":"it_IT"},{"value":"Modal","locale":"en_GB"},{"value":"Modal","locale":"es_ES"},{"value":"Modal","locale":"fr_FR"},{"value":"Modal","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":52,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Viscosa","name":[{"value":"Viscosa","locale":"es_ES"}],"external_identifier":"344748090","description":[{"value":"Viscosa","locale":"it_IT"},{"value":"Viscose","locale":"en_GB"},{"value":"Viscosa","locale":"es_ES"},{"value":"Viscose","locale":"fr_FR"},{"value":"Viscose","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001521606780040(2022-06-02T10:46:51Z(2022-09-30T04:23:03Z(2022-08-15T22:00:01Z$001054280004679040001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore040He0926b57-0529-4a7d-b4ac-aa470e51efeb DELETE<2023-09-02T17:28:25.956757848Z4dataloader-mongo-kafka-job62023-09-02T17:28:46.049861Z(mixer-gtin-agr-kfreeH609e851d-49e4-4b38-8548-8617ee98cc6c62023-09-02T17:31:38.008856Z,mixer-gtin-calc-pcsflmHd0d865e2-3d17-4a47-a1c2-2aeaba84e5e162023-09-02T17:31:44.601744Z,mixer-gtin-calc-pcsflmH050701fb-7962-4028-8b2a-b898654a7ede62023-09-02T22:10:54.312713Z0mixer-product-calc-kfreeH517e683a-cf67-454e-9d76-9d542b8b7423<2024-01-19T11:18:34.135040083Z$mixer-xsell-mixtriHbb8b2be7-60f3-4d35-812a-f26916a6d6bb62024-01-19T11:18:34.240190Z4mixer-packing-units-mixtriH1cf5bd52-375d-4f28-8851-744cb8e021e762024-01-19T11:18:50.007811Z.mixer-offer-badge-mixbiHc7e5f824-0082-4687-a10c-518493d52ee062024-01-19T11:25:56.295607Z.mixer-offer-badge-mixbiH560eb884-e47b-44c6-80e7-4e1b01e4c691(ڀ7ر×cLoffer(A40917745).publish_ends_extendedIVA02IGIC91 +01719001011940017064001711COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001011971101719004&includeAsWebNovelty +es_ESNovedadDVD Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2021-08-27T14:06:27Z +es_ES$SUDADERA RAYAS M/L158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401809748670$000001517629730004TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401809748670126815056ENFASISmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/0S/00/0/0000000S000/0000000S000550mM1011.jpg +es_ESEnfasis +es_ESHomewear999.39072775013 +es_ESHomewear 20.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN001011952200183158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40917745 +es_ESHomewear999.39072775013 +es_ESHomewear 20.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN5925041600923805 +es_ES(CANNON HYGIENE, S.A.CALLE MAR MEDITERRANEO,1-28830 SAN FERNANDO DE HENARES - MADRID (ESPAñA)  +es_ESJSudadera de mujer de felpa soft rayas +es_ESfSudadera tejido de felpa soft de manga larga rayas.A40917745126815056ENFASIS +es_ESENFASIS5925041600923805 +es_ES(CANNON HYGIENE, S.A.CALLE MAR MEDITERRANEO,1-28830 SAN FERNANDO DE HENARES - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeS22H/EFESNM6051 +es_ESJSudadera de mujer de felpa soft rayas +es_ESJSudadera de mujer de felpa soft rayas +es_ESfSudadera tejido de felpa soft de manga larga rayas. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AH00N479439090M +es_ESME +es_ESEspañol479439090M +es_ESM477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-03T00:41:26.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-04T00:41:26.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-02-18T04:14:37.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Chaquetas y camisetas","name":[{"value":"Chaquetas y camisetas","locale":"es_ES"}],"external_identifier":"13993827090","description":[{"value":"Chaquetas y camisetas","locale":"es_ES"}],"type_lookup":"1617"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Esencial","name":[{"value":"Esencial","locale":"es_ES"}],"external_identifier":"40113427090","description":[{"value":"Esencial","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Homewear","name":[{"value":"Homewear","locale":"es_ES"}],"external_identifier":"2700630090","description":[{"value":"Homewear","locale":"es_ES"}],"type_lookup":"1599"}ONEastcg34k65osv2 STRING[{"locale":"en_GB","value":"Navy Memories"},{"locale":"fr_FR","value":"Navy Memories"},{"locale":"pt_PT","value":"Navy Memories"},{"locale":"es_ES","value":"Navy Memories"}]MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"adbyfb4jfvuv5k":100.0,"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517629730004(2022-02-18T04:14:37Z(2022-10-04T00:41:26Z(2022-10-03T00:41:26Z$001011971101719004001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore004H46ed459c-eb2b-4912-ae11-228ee08d0c2c DELETE<2023-09-02T17:29:19.750345780Z4dataloader-mongo-kafka-job62023-09-02T17:29:42.936232Z(mixer-gtin-agr-kfreeH84d03a23-8a98-40da-bf11-6dbdde5d473b62023-09-02T17:34:16.112369Z,mixer-gtin-calc-pcsflmH0eda80e1-7bb0-4b8d-b785-e51bf8b1a78562023-09-02T17:34:20.932158Z,mixer-gtin-calc-pcsflmH630cf81a-bfcf-49b1-b614-b7f37873afcc62023-09-02T22:23:49.766566Z0mixer-product-calc-kfreeHe03d4ab8-b79c-4acc-90f6-9b2c4d3bf879<2024-01-19T11:18:34.402359288Z$mixer-xsell-mixtriH422ed95b-041d-49a5-a5da-7806a35b3ef962024-01-19T11:18:34.464332Z4mixer-packing-units-mixtriH2c952f68-7de2-4e0b-9ed7-6d5bad18d7a362024-01-19T11:18:50.311637Z.mixer-offer-badge-mixbiHa4b216af-5897-4aeb-84cc-3fb2e213d7df62024-01-19T11:25:56.296408Z.mixer-offer-badge-mixbiH41f7efb5-71d3-4a8d-b5b4-e16fdb1d9cf3(܀7ر×c,7ǻmf!؜ Loffer(A28439731).publish_ends_extendedIVA02IGIC91 +01137001001331757976001518COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001001351801137032&includeAsWebNovelty +es_ESNovedadDVD Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2019-05-07T14:17:11Z +es_ES*Sandalia pala PURPURI156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401702306779$000001475460400032TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401702306779173823056NATURAL MENORCA +es_ES Naturals Menorca +es_ESRAccesorios y Zapatos de Hombre e Infantil997.42270706011 +es_ESRAccesorios y Zapatos de Hombre e Infantil 17.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESVAC emisión997.37254410011 +es_ESVAC emisión +8.000 +es_ES2Moda_Zapatos_Informativas997.33067667011 +es_ES2Moda_Zapatos_InformativasCDN +es_ESSandalias999.39073080013 +es_ESSandalias 12.000 +es_ESZapatos niña999.39072680013 +es_ESZapatos niña +3.000 +es_ESZapatos999.39072679013 +es_ESZapatos +5.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN +es_ESVAC canje997.37430941011 +es_ESVAC canje +9.000 +es_ES2Moda_Zapatos_Informativas997.33067667011 +es_ES2Moda_Zapatos_InformativasCDN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A28439731 +es_ESSandalias999.39073080013 +es_ESSandalias 12.000 +es_ESZapatos niña999.39072680013 +es_ESZapatos niña +3.000 +es_ESZapatos999.39072679013 +es_ESZapatos +5.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN5328001600646869 +es_ESDAVARQUES NATURALS DE MENORCA, S.L.CALLE CL CAMI DE SA FAROLA,43-07760 CIUTADELLA DE MENORCA - BALEARES (ESPAñA)  +es_ESSandalias de niña Naturals Menorca de color azul con detalle de purpurina +es_ESSandalia compuesta de goma de TR reciclada suela de cuero legitimo , con pala y tira abierta. De color azul con detalle de purpurina.A28439731173823056NATURALS +es_ESNATURALS5328001600646869 +es_ESDAVARQUES NATURALS DE MENORCA, S.L.CALLE CL CAMI DE SA FAROLA,43-07760 CIUTADELLA DE MENORCA - BALEARES (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeFANT PURPURINA +es_ESSandalias de niña Naturals Menorca de color azul con detalle de purpurinaFANT PURPURINA +es_ESSandalias de niña Naturals Menorca de color azul con detalle de purpurina +es_ESSandalia compuesta de goma de TR reciclada suela de cuero legitimo , con pala y tira abierta. De color azul con detalle de purpurina. calificacion1A2calificacion2Acalificacion3RPcalificacion4VVcalificacion5Bcalificacion6CA0047923409032 +es_ES32E +es_ESEspañol47923409032 +es_ES32477062090Español +Tallapler4twpwa2rdqpwe2kceprh5w3aphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRING.Publicar calif agotadorONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-09-16T04:40:32.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-17T04:40:32.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02019-05-04T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE&MANYa3mfirlezq5meo NUMBER +100.0ONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa6t5qpj7cwnmaw NUMBER +100.0MANYa7jpc7s7go77wi ENTITY{"identifier":"Piel","name":[{"value":"Piel","locale":"es_ES"}],"external_identifier":"347595090","description":[{"value":"Piel","locale":"es_ES"}],"type_lookup":"1633"}{"identifier":"Piel de Flor","name":[{"value":"Piel de Flor","locale":"es_ES"}],"external_identifier":"8753601090","description":[{"value":"Piel de Flor","locale":"es_ES"}],"type_lookup":"1633"}ONEa7xqyqnqtfqof6 ENTITY{"identifier":"Sandalias","name":[{"value":"Sandalias","locale":"es_ES"}],"external_identifier":"462621090","description":[{"value":"Sandalias","locale":"es_ES"}],"type_lookup":"1620"}MANYaao3an6xqyn27u ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}MANYafrdyt4ml6523m ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Goma","name":[{"value":"Goma","locale":"es_ES"}],"external_identifier":"477871090","description":[{"value":"Goma","locale":"es_ES"}],"type_lookup":"1633"}MANYamf7ns2ejiozuc NUMBER +100.0 +100.0MANYamzex7cmn57eei ENTITY{"identifier":"Niña","name":[{"value":"Niña","locale":"es_ES"}],"external_identifier":"357131090","description":[{"value":"Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Mezcla de fibras","name":[{"value":"Mezcla de fibras","locale":"es_ES"}],"external_identifier":"477893090","description":[{"value":"Mezcla de fibras","locale":"es_ES"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Continuidad","name":[{"value":"Continuidad","locale":"es_ES"}],"external_identifier":"2696215090","description":[{"value":"Continuidad","locale":"es_ES"}],"type_lookup":"1577"}ONEauik4rxccjjcze ENTITY{"identifier":"Redonda","name":[{"value":"Redonda","locale":"es_ES"}],"external_identifier":"3020307090","description":[{"value":"Redonda","locale":"es_ES"}],"type_lookup":"1612"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Sandalias","name":[{"value":"Sandalias","locale":"es_ES"}],"external_identifier":"462621090","description":[{"value":"Sandalias","locale":"es_ES"}],"type_lookup":"1620"}MANYauqqk66n7fk6uu ENTITY{"identifier":"Sintético","name":[{"value":"Sintético","locale":"es_ES"}],"external_identifier":"477968090","description":[{"value":"Sintético","locale":"es_ES"}],"type_lookup":"1633"}ONEauur46vhpycka4 ENTITY{"identifier":"Zapatos niña","name":[{"value":"Zapatos niña","locale":"es_ES"}],"external_identifier":"357129090","description":[{"value":"Zapatos niña","locale":"es_ES"}],"type_lookup":"1611"}MANYaxhbfopxaa6ppy ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001475460400032"2019-05-04T22:00Z(2022-09-17T04:40:32Z(2022-09-16T04:40:32Z$001001351801137032001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore032H8264d7a7-b4b8-4ffc-8739-c5f9a060a4fe DELETE<2023-09-02T17:24:16.578180782Z4dataloader-mongo-kafka-job62023-09-02T17:24:24.461033Z(mixer-gtin-agr-kfreeHf29c544c-1e03-4bfb-862c-57fdcc3f4cdb62023-09-02T17:26:07.403768Z,mixer-gtin-calc-pcsflmH475d65f3-af56-424d-9aaa-aea2999b7d7462023-09-02T17:26:11.304909Z,mixer-gtin-calc-pcsflmHffdbef9d-afeb-4baa-b0e2-615be484219962023-09-02T22:11:59.355922Z0mixer-product-calc-kfreeH5451bebd-eff1-4ebe-813f-c4f2891f87f4<2024-01-19T11:18:34.427427719Z$mixer-xsell-mixtriHbbd03ec1-d5fc-42ce-b1df-d4d5d57c3dd762024-01-19T11:18:34.879318Z4mixer-packing-units-mixtriHcfcb0723-dc3f-4714-9474-f82fb29fb1d862024-01-19T11:18:50.321350Z.mixer-offer-badge-mixbiH723d7574-d841-4d00-a6bb-f7e3776da36e62024-01-19T11:25:56.407894Z.mixer-offer-badge-mixbiHa53af118-d12f-4a5d-9c3f-dc21e00b246b(ހ7ر×cIVA02IGIC91 +0883600102023-02-08T06:21:50.934Z051926518523001013COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001051901308836005Marrones +es_ESMarronesMarrones +es_ESMarrones +Camel +es_ES +Camel362774090 +es_ES +Camel599038054255 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___255O3.png +es_ESCOLOR_CAMEL +es_ESColor Camel +Camel +es_ES +Camel0(2018-08-08T12:01:05Z +es_ESE.W.PRENDA EX +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401678419657$000001465121760005TRADICIONAL +es_ESCOLOR_CAMEL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___255O3.png2401678419657124448056EASY WEARmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/1/00001269351/00001269351363mM1011.jpg +es_ESEasy Wear +es_ESPuntoJerseys999.8482561013 +es_ESPunto y Jerseys +9.000 +es_ES2014 Hombre999.2680805013 +es_ES Hombre +2.000 +es_ESModa999.53895013 +es_ESModaNNN +es_ESPuntoJerseys999.8543843013 +es_ESPunto y Jerseys 13.000 +es_ES2015 Joven Él999.8543795013 +es_ESJoven Él 24.000 +es_ESModa999.53895013 +es_ESModaNNN +es_ES Punto y Jerséis999.39072577013 +es_ES Punto y Jerséis +6.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN2401669016346240166901633924016690163222401669016360240166901635324016690163775012123182490A25371488A25552242 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A250152830831537 +es_ES6FANCY FASHION SWEATERS LTD. +es_ESTJersey de hombre Easy Wear con cuello alto +es_ESlJersey de punto con cuello alto y acabados acanalados.A25015283124448056EASY WEAR +es_ESEASY WEAR5388211600831537 +es_ES6FANCY FASHION SWEATERS LTD.CALLE SHAHID SIDDIQUE ROAD, KHAILKUR,1153-1704 GAZIPUR - (BANGLADESH) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeBASIC W18T +es_ESTJersey de hombre Easy Wear con cuello alto +es_ESTJersey de hombre Easy Wear con cuello alto +es_ESlJersey de punto con cuello alto y acabados acanalados. calificacion1Acalificacion2Acalificacion3RIcalificacion4VVcalificacion5NScalificacion6DE0047938109057 +es_ES57E +es_ESEspañol479445090XL +es_ESXL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02018-06-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02019-06-15T22:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02018-10-22T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Alto","name":[{"value":"Alto","locale":"es_ES"}],"external_identifier":"485139090","description":[{"value":"Alto","locale":"es_ES"}],"type_lookup":"1595"}ONEac5swxsdtmjapu ENTITY{"identifier":"Jerseys","name":[{"value":"Jerseys","locale":"es_ES"}],"external_identifier":"347696090","description":[{"value":"Jerseys","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Punto y Jerseys","name":[{"value":"Punto y Jerseys","locale":"es_ES"}],"external_identifier":"2700607090","description":[{"value":"Punto y Jerseys","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Marrón","color_description":[{"value":"Marrón","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Marrón","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4536O3.png","size":"small"}],"description":[{"value":"Marrón","locale":"es_ES"}],"identifier":"4536","name":[{"value":"COLOR_MARRON","locale":"es_ES"}],"external_identifier":"599598054"},"identifier":"Marrón","name":[{"value":"Marrón","locale":"es_ES"}],"external_identifier":"344718090"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":70.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":30.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2018Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001465121760005"2018-10-22T22:00Z(2019-06-15T22:00:01Z(2018-06-15T22:00:01Z$001051901308836005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H3b7d92de-72c0-450b-bd9e-34287900140c DELETE<2023-09-02T17:11:27.556687563Z4dataloader-mongo-kafka-job62023-09-02T17:11:37.155240Z(mixer-gtin-agr-kfreeHff7759e1-4211-43c9-9fde-f4308fdb6ce262023-09-02T17:11:47.449588Z,mixer-gtin-calc-pcsflmH6c3c80cb-7441-49aa-8ffb-c25f4561a78662023-09-02T17:11:47.515149Z,mixer-gtin-calc-pcsflmHe9426ff6-fa61-4747-8914-7fc7b2c82c8162023-09-03T02:39:50.790446Z0mixer-product-calc-kfreeH3fc36c1f-a83d-4c92-b248-29b5a8db1987<2024-01-19T11:18:34.821675768Z$mixer-xsell-mixtriH1ca92b11-265a-4565-b111-24fe454d259462024-01-19T11:18:34.941636Z4mixer-packing-units-mixtriH7680c546-ec6e-4393-9875-e94c19238f8962024-01-19T11:18:50.334805Z.mixer-offer-badge-mixbiH472a78d9-b690-4183-9152-12badc05419262024-01-19T11:25:56.408572Z.mixer-offer-badge-mixbiHdd817c95-fd27-4ecb-88b6-51f0902ff42f(7ر×cLoffer(A45376023).publish_ends_extendedIVA02IGIC91 +00411001009644045407001339COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001009633900411005&includeAsWebNovelty +es_ESNovedadDVD Verdes +es_ES Verdes Verdes +es_ES VerdesKaki +es_ESKaki347728090 +es_ESKaki5992820543807 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___3807O2.png +es_ESCOLOR_KAKI +es_ESColor KakiKaki +es_ESKaki0(2022-10-17T11:20:43Z +es_ES,BAÑADOR GEOMETRICO BI155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401854330011$000001536834510005TRADICIONAL +es_ESCOLOR_KAKI +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___3807O2.png24018543300117460234056 ECOALF +es_ES Ecoalf +es_ES"Banadores bermuda999.39091449013 +es_ES"Banadores bermuda +1.000 +es_ES +Baño999.39072781013 +es_ES +Baño +3.000 +es_ES Interior y baño999.39072777013 +es_ES Interior y baño +4.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A45376023 +es_ES"Banadores bermuda999.39091449013 +es_ES"Banadores bermuda +1.000 +es_ES +Baño999.39072781013 +es_ES +Baño +3.000 +es_ES Interior y baño999.39072777013 +es_ES Interior y baño +4.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNNN4819551600000123 +es_ES8ECOALF RECYCLED FABRICS S.L.dCALLE GRAN VíA,1-28013 MADRID - MADRID (ESPAñA)  +es_ES:Bañador total goma de hombre +es_ESHBañador con goma estampado bicolor.A453760237460234056 ECOALF +es_ES ECOALF4819551600000123 +es_ES8ECOALF RECYCLED FABRICS S.L.dCALLE GRAN VíA,1-28013 MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeA EXTINGUIR +es_ES:Bañador total goma de hombre +es_ES:Bañador total goma de hombre +es_ESHBañador con goma estampado bicolor. calificacion1Acalificacion2Acalificacion3M2calificacion4VVcalificacion5ACcalificacion6V00N479445090XL +es_ESXLE +es_ESEspañol4793600905 +es_ES518171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-07T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-08T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar en agua fría","name":[{"value":"Lavar en agua fría","locale":"es_ES"}],"external_identifier":"349555090","description":[{"value":"Lavar en agua fría","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Lavado Delicado","name":[{"value":"Lavado Delicado","locale":"es_ES"}],"external_identifier":"8955928090","description":[{"value":"Lavado Delicado","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar blanqueante","name":[{"value":"No usar blanqueante","locale":"es_ES"}],"external_identifier":"484894090","description":[{"value":"No usar blanqueante","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No planchar","name":[{"value":"No planchar","locale":"es_ES"}],"external_identifier":"350554090","description":[{"value":"No planchar","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No Planchar","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___840O1.png","size":"small"}],"description":[{"value":"No Planchar","locale":"es_ES"}],"identifier":"840","name":[{"value":"NO_PLANCHAR","locale":"es_ES"}],"external_identifier":"600047054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Geométrico","name":[{"value":"Geométrico","locale":"es_ES"}],"external_identifier":"25521450090","description":[{"value":"Geométrico","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bañadores bermuda","name":[{"value":"Bañadores bermuda","locale":"es_ES"}],"external_identifier":"2682047090","description":[{"value":"Bañadores bermuda","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Baño","name":[{"value":"Baño","locale":"es_ES"}],"external_identifier":"349577090","description":[{"value":"Baño","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX {"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida / Nailon","name":[{"value":"Poliamida / Nailon","locale":"es_ES"}],"external_identifier":"10941217090","description":[{"value":"Poliammide / Nylon","locale":"it_IT"},{"value":"Polyamide/Nylon","locale":"en_GB"},{"value":"Poliamida / Nailon","locale":"es_ES"},{"value":"Polyamide / Nylon","locale":"fr_FR"},{"value":"Poliamida / Nylon","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2023Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001536834510005"2022-10-08T22:00Z"2022-10-07T22:00Z$001009633900411005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H65439bf8-9874-4ae2-8b91-482070342210 DELETE<2023-09-02T17:32:01.475713427Z4dataloader-mongo-kafka-job62023-09-02T17:34:09.392079Z(mixer-gtin-agr-kfreeHfe2ae75f-6d68-4957-81d8-1c87153ad1ca62023-09-02T17:45:27.808184Z,mixer-gtin-calc-pcsflmH7c65c9c5-7cfb-4feb-80a7-a149f2c7243c62023-09-02T17:45:32.906243Z,mixer-gtin-calc-pcsflmH957912b9-ad75-46ee-a1d5-51a552c6c84662023-09-02T23:25:48.260052Z0mixer-product-calc-kfreeHd263bf15-5102-4358-8598-755e0e9e7c6a<2024-01-19T11:18:48.029556550Z$mixer-xsell-mixtriH2f7b8ee1-880c-4714-84ab-9002026324ba62024-01-19T11:18:48.286585Z4mixer-packing-units-mixtriHbd06af12-537b-4d4f-a133-eef547ac92ba62024-01-19T11:18:50.341486Z.mixer-offer-badge-mixbiH78c6e75b-6c46-478d-9bf7-3d1a315a401962024-01-19T11:25:56.409300Z.mixer-offer-badge-mixbiH13025da2-a2f0-4ffa-8144-fcdd08a9c327(※7ر×cLoffer(A43278472).publish_ends_extendedIVA02IGIC92 +85613001006241960838001154COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001006215485613 &includeAsWebNovelty +es_ESNovedadDVD"2022-03-17T23:00Z0195031488238Natural +es_ESNaturalNatural +es_ESNatural +Beige +es_ES +Beige344754090 +es_ES +Beige599054054 +25619 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100629/___25619O1.png +es_ESCOLOR_BEIGE +es_ESColor Beige +Beige +es_ES +Beige0(2022-03-21T14:05:48Z +es_ESKIRA BOLSOS158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000195031488238$000000000152795885TRADICIONAL +es_ESCOLOR_BEIGE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100629/___25619O1.png240183321323618549657056 +COACH +es_ES +Coach +es_ESModa mujer997.44571721011 +es_ESModa mujer 21.000 +es_ES30997.39154516011 +es_ES30 +4.000 +es_ESjCross - Contenedor Venta Privada NO Acumulable OI2223997.39128268011 +es_ESLContenedor Venta Privada no acumulableCDNN +es_ES Bolsos pequeños999.39072346013 +es_ES Bolsos pequeños +8.000 +es_ES Bolsos999.39072321013 +es_ES Bolsos +3.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ES Bolsos999.39072321013 +es_ES Bolsos +3.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNN +es_ESBandoleras999.39072322013 +es_ESBandoleras +3.000 +es_ES Bolsos999.39072321013 +es_ES Bolsos +3.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43278472 +es_ES Bolsos pequeños999.39072346013 +es_ES Bolsos pequeños +8.000 +es_ES Bolsos999.39072321013 +es_ES Bolsos +3.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0906210 +es_ESDCOACH OPERATIONS SINGAPORE PTE LTD +es_ESFBandolera bicolor con asa regulable +es_ESBolso bandolera bicolor con cierre de cremallera, que representa la auténtica versatilidad, cuenta con un tamaño perfecto y puede llevarse cruzado, como bolso pouch, como bolso de mano o como bolsa dentro de un bolso más grande. Fabricado en piel y canvas, este bolso dispone de dos compartimentos con cremallera y un práctico bolsillo central para documentos con capacidad para el móvil, las tarjetas, las llaves y todo lo demás. Viene acompañado de una correa de hombro ajustable y otra de muñeca para darle un estilo elegante.A4327847218549657056 +COACH +es_ES +COACH0906210 +es_ESDCOACH OPERATIONS SINGAPORE PTE LTD998.00194 +es_ESComplementos998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosC8475 B4TXJ +es_ESFBandolera bicolor con asa regulable +es_ESFBandolera bicolor con asa regulable +es_ESBolso bandolera bicolor con cierre de cremallera, que representa la auténtica versatilidad, cuenta con un tamaño perfecto y puede llevarse cruzado, como bolso pouch, como bolso de mano o como bolsa dentro de un bolso más grande. Fabricado en piel y canvas, este bolso dispone de dos compartimentos con cremallera y un práctico bolsillo central para documentos con capacidad para el móvil, las tarjetas, las llaves y todo lo demás. Viene acompañado de una correa de hombro ajustable y otra de muñeca para darle un estilo elegante. calificacion1Acalificacion2Acalificacion3E5calificacion4VVcalificacion5AAcalificacion6FI00Npler4twpwa2rdqpeymj6wu3nmofgpaxawji3i4mkoqMANYa5wg3q7jlozdji ENTITY{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"}],"type_lookup":"1633"}ONEa5wuherdryc3vm NUMBER4.1MANYa5xfo2abga2eme NUMBER2022ONEa64wijst5hogcs ENTITY{"identifier":"Cremallera","name":[{"value":"Cremallera","locale":"es_ES"}],"external_identifier":"348040090","description":[{"value":"Cremallera","locale":"es_ES"}],"type_lookup":"1574"}ONEaa72dm3yz6vb5u ENTITY{"identifier":"Bandoleras","name":[{"value":"Bandoleras","locale":"es_ES"}],"external_identifier":"344782090","description":[{"value":"Bandoleras","locale":"es_ES"}],"type_lookup":"1619"}ONEacu3nzdu3mtllm NUMBER18.8ONEacyfplvd6an7xo STRING[{"locale":"es_ES","value":"Liso"},{"locale":"pt_PT","value":"Liso"}]ONEafbexdxymegola ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}ONEamh4yuywyr3pna NUMBER10.2ONEanxumtnaxc7bmw ENTITY{"identifier":"Bolsos","name":[{"value":"Bolsos","locale":"es_ES"}],"external_identifier":"344779090","description":[{"value":"Bolsos","locale":"es_ES"}],"type_lookup":"1573"}MANYarbqbgl5kiiqhmCOMPLEX{"awtfizlwej3num":{"identifier":"Exterior","name":[{"value":"Exterior","locale":"es_ES"}],"external_identifier":"477727090","description":[{"value":"Outdoor","locale":"en_GB"},{"value":"Exterior","locale":"es_ES"},{"value":"Eclairage extérieur","locale":"fr_FR"},{"value":"Exterior","locale":"pt_PT"}],"type_lookup":"1576"},"a3gd23j3lhtuz2":[{"a23xjq2h2haw5g":65,"a5shyljk4cvjq6":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"ajxlygljz2ct42":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}{"awtfizlwej3num":{"identifier":"Exterior","name":[{"value":"Exterior","locale":"es_ES"}],"external_identifier":"477727090","description":[{"value":"Outdoor","locale":"en_GB"},{"value":"Exterior","locale":"es_ES"},{"value":"Eclairage extérieur","locale":"fr_FR"},{"value":"Exterior","locale":"pt_PT"}],"type_lookup":"1576"},"a3gd23j3lhtuz2":[{"a23xjq2h2haw5g":35,"a5shyljk4cvjq6":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"ajxlygljz2ct42":{"identifier":"Piel vacuna","name":[{"value":"Piel vacuna","locale":"es_ES"}],"external_identifier":"347772090","description":[{"value":"Pelle bovina","locale":"it_IT"},{"value":"Cowhide","locale":"en_GB"},{"value":"Piel vacuna","locale":"es_ES"},{"value":"Cuir vachette","locale":"fr_FR"},{"value":"Pele de bovino","locale":"pt_PT"}],"type_lookup":"1633"}}]}ONEasw5v2d7nudvia ENTITY{"identifier":"Asa regulable","name":[{"value":"Asa regulable","locale":"es_ES"}],"external_identifier":"32681477090","description":[{"value":"Asa regulable","locale":"es_ES"}],"type_lookup":"1566"}MANYaz2gbwdmqlkyim ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYazrazbd5hx4qa4 ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"} Complementos_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-05-23T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-02T06:46:20.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-05-24T03:58:31.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000152795885(2022-05-24T03:58:31Z(2022-10-02T06:46:20Z"2022-05-23T22:00Z$001006215485613 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hcae16104-4fba-48d8-a789-ef66af9b28a4 DELETE<2023-09-02T17:29:38.355922242Z4dataloader-mongo-kafka-job62023-09-02T17:30:19.204051Z(mixer-gtin-agr-kfreeH5448a47b-f1f8-4594-bcee-f7469647f01e62023-09-02T17:31:58.615775Z,mixer-gtin-calc-pcsflmH9dc00d59-1e41-4fbc-8957-40e1daf34ebd62023-09-02T17:31:59.823738Z,mixer-gtin-calc-pcsflmHf46461fd-f674-4c56-8e8d-5e854a89c38462023-09-02T22:21:17.868733Z0mixer-product-calc-kfreeH2511673e-65e5-4d2e-99f3-7e0d1871e1ef<2024-01-19T11:18:48.739952109Z$mixer-xsell-mixtriH68f9f054-9134-4657-905d-7e8d0c704ff862024-01-19T11:18:48.841161Z4mixer-packing-units-mixtriH893d5cd1-23a0-4847-b8b4-d9e1f84450ab62024-01-19T11:18:50.352217Z.mixer-offer-badge-mixbiH3abb5dc6-0b03-417b-96b7-1199efdcd8e862024-01-19T11:25:56.484988Z.mixer-offer-badge-mixbiH484dc401-22cf-40c6-be84-03a178bc522b(䀻7ر×cLoffer(A36314007).publish_ends_extendedIVA02IGIC91 +04014001A008436292002001465VPR +es_ESVPRCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001008446504014 &includeAsWebNovelty +es_ESNovedadDVD +es_ES Centro Comercial7892613090 Centro Comercial +es_ES Centro Comercial(2023-01-24T02:48:25ZDVD"2020-07-14T22:00Z8431284873219 Negros +es_ES Negros Negros +es_ES NegrosNegro / Gris +es_ESNegro / Gris355892090 +es_ESNegro / Gris600190054 +94410 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/23/___94410O1.png +es_ES COLOR_NEGRO/GRIS +es_ES Color Negro/GrisNegro / Gris +es_ESNegro / Gris0(2020-08-01T08:38:32Z +es_ES(CINTA LKT8 TREADMILL26 +es_ESVPR274981090VPR395ML +es_ESml +0.0008431284873219$000000000150231184TRADICIONAL +es_ES COLOR_NEGRO/GRIS +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/23/___94410O1.png2401769265088123742056BH FITNESS +es_ESBH Fitness +es_ES Cintas de Correr999.53703013 +es_ES Cintas de correr +3.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESDDeportes - Contenedor rebajas OI22997.44869638011 +es_ESDDeportes - Contenedor rebajas OI22N26 +es_ESVPR274981090VPR395A36314007 +es_ES Cintas de Correr999.53703013 +es_ES Cintas de correr +3.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN5128061600342873 +es_ESEXERCYCLE, S.L.CALLE ZURRUPITIETA ,22(POL.JUNDIZ),.-01015 VITORIA - ALAVA-ARABA (ESPAñA)  +es_ESVCinta de correr LKT8 Profesional BH Fitness +es_ES +La cinta de correr LKT8 es uno de los modelos de BH más vendido en Estados Unidos.Con prestaciones y estructura profesional, esta cinta te permitirá volver a entrenar como en el gimnasio pero desde tu casa.Chasis muy robusto que proporciona máxima estabilidad y durabilidad.^Superficie de carrera extra-amplia de 155x55 cmDiseñada para un confort total y una seguridad garantizada durante los usos.DPotente motor profesional de 3,5CVEquipada con un motor muy silencioso que alcanza velocidad de hasta 20km/hInclinación máxima del 15% para entrenamientos más intensivos.bSistema de amortiguación Active Flex suspension.La tecnología de amortiguación Active Flex permite un impacto más suave y un empuje firme para mayor comodidad y eficiencia al correr.Banda Ortopédica: Aumenta el confort en la pisada disminuyendo el impacto en la planta del pie.hMonitor LED de fácil lectura con circuito simulado. +Programas predeterminados que combinan velocidad e inclinación.~Programa de pulso constante para entrenamientos más avanzados.JProgramas personalizables de usuario.Teclado con velocidad e inclinación preestablecidas. Las teclas predefinidas de velocidad e inclinación permiten ajustes rápidos a las configuraciones más comunes.Medición de pulso inalámbrica con banda de pecho (no incluida) mediante radiofrecuencia a 5 kHz: Permite realizar entrenamientos de gran intensidad con un cómodo control del ritmo cardiaco en el monitor. Nota importante:La banda de pecho y otros dispositivos no van incluidos, se venden por separado. +pt_PT +A passadeira LKT8 é um dos modelos da BH mais vendidos nos Estados Unidos.Com estrutura profissional, esta passadeira permitirá que volte a treinar como no ginásio, mas a partir de casa.Chassis muito robusto que proporciona máxima estabilidade e durabilidade.PSuperfície bastante ampla de 155x55 cm.Desenhada para um conforto total e uma segurança garantida durante a utilização.JPotente motor profissional de 3,5 CV.Equipada com um motor muito silencioso que alcança velocidade de até 20 km/h.rInclinação máxima de 15% para treinos mais intensivos.^Sistema de amortização suspensão Active FlexA tecnologia de amortização Active Flex permite um impacto mais suave e um impulso firme para maior comodidade e eficiência ao correr.Banda ortopédica: Aumenta o conforto na pisada, diminuindo o impacto na planta do pé.fMonitor LED de fácil leitura com circuito simulado +Programas predeterminados que combinam velocidade e inclinação.rPrograma de pulso constante para treinos mais avançados.\Programas personalizados consoante utilizador.Teclado com velocidade e inclinação pré estabelecidas. As teclas de velocidade e inclinação permitem ajustes rápidos às configurações mais comuns.Medição de pulso sem fios com banda de peito (não incluído). Permite realizar treinos de grande intensidade com um cómodo controlo do ritmo cardíaco no monitor. Nota importante:A banda de peito e outros dispositivos não estão incluídos. Vendem-se separadamente.A36314007123742056BH FITNESS +es_ESBH FITNESS5128061600342873 +es_ESEXERCYCLE, S.L.CALLE ZURRUPITIETA ,22(POL.JUNDIZ),.-01015 VITORIA - ALAVA-ARABA (ESPAñA) 998.00192 +es_ESFitness998.00189 +es_ESDeportes998 +es_ES@Jerarquía de Ficha de Productos5128061600342873 +es_ESEXERCYCLE, S.L.CALLE ZURRUPITIETA ,22(POL.JUNDIZ),.-01015 VITORIA - ALAVA-ARABA (ESPAñA) LKT8 +es_ESVCinta de correr LKT8 Profesional BH Fitness +es_ESVCinta de correr LKT8 Profesional BH Fitness9999999.000 +es_ES +La cinta de correr LKT8 es uno de los modelos de BH más vendido en Estados Unidos.Con prestaciones y estructura profesional, esta cinta te permitirá volver a entrenar como en el gimnasio pero desde tu casa.Chasis muy robusto que proporciona máxima estabilidad y durabilidad.^Superficie de carrera extra-amplia de 155x55 cmDiseñada para un confort total y una seguridad garantizada durante los usos.DPotente motor profesional de 3,5CVEquipada con un motor muy silencioso que alcanza velocidad de hasta 20km/hInclinación máxima del 15% para entrenamientos más intensivos.bSistema de amortiguación Active Flex suspension.La tecnología de amortiguación Active Flex permite un impacto más suave y un empuje firme para mayor comodidad y eficiencia al correr.Banda Ortopédica: Aumenta el confort en la pisada disminuyendo el impacto en la planta del pie.hMonitor LED de fácil lectura con circuito simulado. +Programas predeterminados que combinan velocidad e inclinación.~Programa de pulso constante para entrenamientos más avanzados.JProgramas personalizables de usuario.Teclado con velocidad e inclinación preestablecidas. Las teclas predefinidas de velocidad e inclinación permiten ajustes rápidos a las configuraciones más comunes.Medición de pulso inalámbrica con banda de pecho (no incluida) mediante radiofrecuencia a 5 kHz: Permite realizar entrenamientos de gran intensidad con un cómodo control del ritmo cardiaco en el monitor. Nota importante:La banda de pecho y otros dispositivos no van incluidos, se venden por separado. +pt_PT +A passadeira LKT8 é um dos modelos da BH mais vendidos nos Estados Unidos.Com estrutura profissional, esta passadeira permitirá que volte a treinar como no ginásio, mas a partir de casa.Chassis muito robusto que proporciona máxima estabilidade e durabilidade.PSuperfície bastante ampla de 155x55 cm.Desenhada para um conforto total e uma segurança garantida durante a utilização.JPotente motor profissional de 3,5 CV.Equipada com um motor muito silencioso que alcança velocidade de até 20 km/h.rInclinação máxima de 15% para treinos mais intensivos.^Sistema de amortização suspensão Active FlexA tecnologia de amortização Active Flex permite um impacto mais suave e um impulso firme para maior comodidade e eficiência ao correr.Banda ortopédica: Aumenta o conforto na pisada, diminuindo o impacto na planta do pé.fMonitor LED de fácil leitura com circuito simulado +Programas predeterminados que combinam velocidade e inclinação.rPrograma de pulso constante para treinos mais avançados.\Programas personalizados consoante utilizador.Teclado com velocidade e inclinação pré estabelecidas. As teclas de velocidade e inclinação permitem ajustes rápidos às configurações mais comuns.Medição de pulso sem fios com banda de peito (não incluído). Permite realizar treinos de grande intensidade com um cómodo controlo do ritmo cardíaco no monitor. Nota importante:A banda de peito e outros dispositivos não estão incluídos. Vendem-se separadamente. calificacion1A5calificacion2ACcalificacion3M5calificacion4VVcalificacion5EPcalificacion6TV00 +peohixr7rbw25wpler4twpwa2rdqpfzvcd4keku3ogpaxawji3i4mkoqpzemnwoecgod3uONEadxazarzusz3teBOOLEAN +falseONEatos7dqm35n3ma NUMBER9999999Comunes_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"locale":"es_ES","value":"011"}],"external_identifier":"233768090","description":[{"locale":"es_ES","value":"Gestión Automática - Despublica publicadas sin stock ECI"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02021-07-29T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-09T11:30:35.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02020-07-30T09:05:00.000ZONEate3liesiuooycBOOLEANtrueMANYavq6mln3ba72gy ENTITY{"identifier":"Centro Comercial","name":[{"locale":"es_ES","value":"Centro Comercial"}],"external_identifier":"7892613090","description":[{"locale":"es_ES","value":"Centro Comercial"}],"type_lookup":"10154"}MANYaqundqcyqbyf5mTIMESTAMP02023-01-24T02:48:25.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE*ONEa2ywby6ptmqf6m STRINGT[{"locale":"es_ES","value":"155 x 55 cm"}]ONEa6jk4l3fu5eo3i NUMBER20ONEaaaowmmw6jvu4k ENTITY{"identifier":"Cintas de correr","name":[{"locale":"es_ES","value":"Cintas de correr"}],"external_identifier":"358859090","description":[{"locale":"es_ES","value":"Cintas de correr"}],"type_lookup":"1555"}ONEaaqvqmiyq3ib5g ENTITY{"identifier":"CV","name":[{"locale":"es_ES","value":"CV"}],"external_identifier":"353326090","description":[{"locale":"es_ES","value":"CV"}],"type_lookup":"208"}ONEabdruvrjx4scqe ENTITY{"identifier":"cm","name":[{"locale":"es_ES","value":"cm"}],"external_identifier":"347186090","description":[{"locale":"es_ES","value":"cm"}],"type_lookup":"204"}ONEabp5vcptqgloeg NUMBER +130.0ONEac6yc2cx3n3ngu ENTITY{"identifier":"kg","name":[{"locale":"es_ES","value":"kg"}],"external_identifier":"348777090","description":[{"locale":"es_ES","value":"kg"}],"type_lookup":"206"}ONEadmzq3hkpito7a NUMBER15ONEajv3rss7qbcgra ENTITY{"identifier":"Profesional","name":[{"locale":"es_ES","value":"Profesional"}],"external_identifier":"474754090","description":[{"locale":"es_ES","value":"Profesional"}],"type_lookup":"1554"}ONEamopyzyiubcgcy STRING Dot Matrix (LED)ONEansytyxo2glo26 ENTITY{"identifier":"km/h","name":[{"locale":"es_ES","value":"km/h"}],"external_identifier":"353327090","description":[{"locale":"es_ES","value":"km/h"}],"type_lookup":"212"}ONEapdtu4tnalmwuu NUMBER10ONEaqkf2pubvohm4w ENTITY{"identifier":"kg","name":[{"locale":"es_ES","value":"kg"}],"external_identifier":"348777090","description":[{"locale":"es_ES","value":"kg"}],"type_lookup":"206"}ONEaqxl7ilbbt4o6w ENTITY{"identifier":"%","name":[{"locale":"es_ES","value":"%"}],"external_identifier":"344726090","description":[{"locale":"es_ES","value":"%"}],"type_lookup":"214"}ONEarfknjo4vwunhc NUMBER190ONEatgae2m5w7q3w2 NUMBER147ONEatlh77et6ahb4q NUMBER3.5ONEavdareqsk6alv2 ENTITY{"identifier":"Sí","name":[{"locale":"es_ES","value":"Sí"}],"external_identifier":"465783090","description":[{"locale":"es_ES","value":"Sí"}],"type_lookup":"1553"}ONEavxjpjfvbxjewk NUMBER206ONEay6766aojywp52 ENTITY{"identifier":"Eléctrica","name":[{"locale":"es_ES","value":"Eléctrica"}],"external_identifier":"467648090","description":[{"locale":"es_ES","value":"Eléctrica"}],"type_lookup":"144"}ONEayixta66deptau NUMBER84Fitness_ISS.SPEC_SECONDARY_TEMPLATE +es_ESSupervoluminoso348626090Supervoluminoso +es_ESSupervoluminoso401$000000000150231184"2020-07-30T09:05Z(2022-10-09T11:30:35Z"2021-07-29T22:00Z$001008446504014 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore 16H49c6eb42-af38-4964-84b0-f6a5ccdbe39b DELETE<2023-09-02T17:32:04.086337231Z4dataloader-mongo-kafka-job62023-09-02T17:38:06.937541Z(mixer-gtin-agr-kfreeH7ba17fd6-27cd-42dc-8df3-4c5cec71067162023-09-02T17:50:16.133911Z,mixer-gtin-calc-pcsflmH7dbb1805-078f-442a-939d-74ca43d67e5562023-09-02T17:50:22.204309Z,mixer-gtin-calc-pcsflmH553e0d9a-c41a-47f3-aba8-86ce33bc5c9262023-09-02T23:32:05.453866Z0mixer-product-calc-kfreeH35b9b98e-47fe-4a90-acf0-f1f22243e8aa<2024-01-19T11:18:49.056154412Z$mixer-xsell-mixtriHf802ebba-d252-4d75-9361-c641bebc8eea62024-01-19T11:18:49.188590Z4mixer-packing-units-mixtriH3d026e28-9ffb-49e5-befe-f3fcf25df02962024-01-19T11:18:50.409237Z.mixer-offer-badge-mixbiHcf39ede1-1d20-435e-9b25-6f311d0fb07762024-01-19T11:25:56.485912Z.mixer-offer-badge-mixbiH964aa555-f1f5-4a74-a5e8-bf6c752cd6ca(总7ر×cLoffer(A41117860).publish_ends_extendedIVA02IGIC91 +10000001011040725867001201COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001011020110000007&includeAsWebNovelty +es_ESNovedadDVD"2021-09-13T22:00Z0089129681949 +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa +es_ESRosa347700090 +es_ESRosa5985060542019 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png +es_ESCOLOR_ROSA +es_ESColor RosaRosa +es_ESRosa0(2021-11-16T15:33:29Z +es_ES"SUJETADOR SIN ARO158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000089129681949$000001518325800007TRADICIONAL +es_ESCOLOR_ROSA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png2401811402201324991056DKNYmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/9/00001269359/00001269359018mM1011.jpg +es_ESDkny  +es_ESLencería997.44393424011 +es_ESLencería +7.000 +es_ESXCross - Contenedor 2022 Black Friday Moda 20997.44305664011 +es_ES(Black Friday Moda 20CDN +es_ESLencería997.40934801011 +es_ESLencería +1.000 +es_ESModa Mujer997.40925038011 +es_ESModa Mujer +2.000 +es_ES$Cross - Feliz 2023997.40925036011 +es_ESFeliz 2023CDNN +es_ESModa mujer997.44571721011 +es_ESModa mujer 21.000 +es_ES30997.39154516011 +es_ES30 +4.000 +es_ESjCross - Contenedor Venta Privada NO Acumulable OI2223997.39128268011 +es_ESLContenedor Venta Privada no acumulableCDNN +es_ES&Sujetadores sin aro999.39072748013 +es_ES&Sujetadores sin aro +7.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 11.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ESLencería997.44393460011 +es_ESLencería +1.000 +es_ESModa Mujer997.44393459011 +es_ESModa Mujer +6.000 +es_ESHCross - Contenedor 2022 Cyber Monday997.44305671011 +es_ESContenedor CMCDNN +es_ESLencería997.41964064011 +es_ESLencería +6.000 +es_ESModa Mujer997.41875780011 +es_ESModa Mujer 32.000 +es_ES6Cross - Contenedor 8DO pv22997.41837795011 +es_ES&Contenedor 8DO pv22CDNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41117860 +es_ES&Sujetadores sin aro999.39072748013 +es_ES&Sujetadores sin aro +7.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 11.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0018597 +es_ES,PASARELA INTERIORES SL +es_ES"Sujetador sin aro +es_ESSujetador sin aro liso tipo top con tejido algodón y logo en cinturillaA41117860324991056DKNY +es_ESDKNY13124271600018597 +es_ES,PASARELA INTERIORES SLzCALLE CRTA MASNOU,255-08401 GRANOLLERS - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize DK4519 +es_ES"Sujetador sin aro +es_ES"Sujetador sin aro +es_ESSujetador sin aro liso tipo top con tejido algodón y logo en cinturilla +calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5AHPDN479437090L +es_ESLE +es_ESEspañol479437090L +es_ESL477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-01T05:38:05.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-02T05:38:05.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-02-03T05:09:27.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}{"identifier":"No centrifugar","name":[{"value":"No centrifugar","locale":"es_ES"}],"external_identifier":"347781090","description":[{"value":"No centrifugar","locale":"es_ES"}],"type_lookup":"1584"}MANYa3kybygykw5doe ENTITY{"identifier":"Top","name":[{"value":"Top","locale":"es_ES"}],"external_identifier":"23556456090","description":[{"value":"Top","locale":"es_ES"}],"type_lookup":"2505"}ONEa4aig6savkv75m STRING[{"locale":"es_ES","value":"Trasero"},{"locale":"pt_PT","value":"Traseiro"}]MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Sujetadores sin aro","name":[{"value":"Sujetadores sin aro","locale":"es_ES"}],"external_identifier":"12873137090","description":[{"value":"Sujetadores sin aro","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYagio3trrjaqhgg ENTITY{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sujetadores","name":[{"value":"Sujetadores","locale":"es_ES"}],"external_identifier":"2700632090","description":[{"value":"Sujetadores","locale":"es_ES"}],"type_lookup":"1599"}MANYaj3ufdvuwowrlw ENTITY{"identifier":"Sin aro","name":[{"value":"Sin aro","locale":"es_ES"}],"external_identifier":"2696269090","description":[{"value":"Sin aro","locale":"es_ES"}],"type_lookup":"1601"}ONEastcg34k65osv2 STRING[{"locale":"es_ES","value":"Cozy Boyfriend"},{"locale":"pt_PT","value":"Cozy Boyfriend"}]MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":52,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":35,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Modal","name":[{"value":"Modal","locale":"es_ES"}],"external_identifier":"347876090","description":[{"value":"Modal","locale":"it_IT"},{"value":"Modal","locale":"en_GB"},{"value":"Modal","locale":"es_ES"},{"value":"Modal","locale":"fr_FR"},{"value":"Modal","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":13,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518325800007(2022-02-03T05:09:27Z(2022-10-02T05:38:05Z(2022-10-01T05:38:05Z$001011020110000007001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore007Hf26bba6f-f6fe-4ffa-890e-ab5bdab6e8c1 DELETE<2023-09-02T17:29:19.037383886Z4dataloader-mongo-kafka-job62023-09-02T17:29:47.359987Z(mixer-gtin-agr-kfreeHa7580263-126e-40aa-8198-1414a3828a8562023-09-02T17:33:55.417285Z,mixer-gtin-calc-pcsflmH3de22d8f-5458-4d6e-88d3-956d8bf37c3d62023-09-02T17:34:00.921006Z,mixer-gtin-calc-pcsflmH9be2e9fd-0f16-4714-9372-cf622790f07d62023-09-03T03:02:03.386933Z0mixer-product-calc-kfreeHe0c1ed54-6fb2-437d-8220-bcbca9c81619<2024-01-19T11:18:35.450691690Z$mixer-xsell-mixtriH4748af71-1885-4ebf-a5c6-f235dc1b075f62024-01-19T11:18:35.601568Z4mixer-packing-units-mixtriHe286e631-153b-437d-b701-c838594a2d5662024-01-19T11:18:50.451888Z.mixer-offer-badge-mixbiHe81b6a1e-47b2-4cc6-ae67-226706d6699262024-01-19T11:25:56.487597Z.mixer-offer-badge-mixbiHa1070de9-f673-492c-9c2d-283414eb1918(耻7ر×cLoffer(A15111291).publish_ends_extendedIVA02IGIC92"2015-10-22T22:01Z +2912600109758185589001735COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001097573529126 &includeAsWebNovelty +es_ESNovedadDVD"2015-04-07T22:00Z2975735291260"2015-04-07T22:00Z50309171712390(2015-04-14T11:16:59Z +es_ES*GUITAR HERO LIVE X36056 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005030917171239$0000000001078453182401554953169123393056ACTIVISION +es_ESActivision +es_ES Juegos999.53538013 +es_ES Juegos +2.000 +es_ESXbox 360999.54056013 +es_ESXbox 360 36.000 +es_ESVideojuegos999.51648013 +es_ESVideojuegosNNN +es_ES Juegos997.32798013011 +es_ES Juegos +2.000 +es_EShVideojuegos, Liquidación Videojuegos Noviembre 2019997.32793599011 +es_ES$Outlet VideojuegosCDN56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A15111291 +es_ES Juegos999.53538013 +es_ES Juegos +2.000 +es_ESXbox 360999.54056013 +es_ESXbox 360 36.000 +es_ESVideojuegos999.51648013 +es_ESVideojuegosNNN0015370 +es_ESPACTIVISION BLIZZARD SPAIN, S.L.UNIPERSON +es_ESHGuitar Hero Live + Guitarra Xbox 360 +es_ESjMás real que nunca. Guitar Hero Live ya está aquí.FreeStyleGames ha reinventado la legendaria franquicia de Guitar Hero, con dos innovadores modos de juego y un mando de guitarra completamente renovado.El modo GH Live te sitúa en el escenario: observa en primera persona cómo reacciona el público real a las notas que toques.También puedes pasarte a GHTV, una red de vídeos musicales jugables donde podrás tocar en tiempo real, descubrir nueva música y desafiar a amigos de todo el mundo.jEl nuevo Guitar Hero. Un juego. Dos maneras de jugar.GH Live, donde podrás tocar ante un público real y ver sus reacciones reales, y GHTV, una transmisión continua de vídeos musicales, con una biblioteca de centenares de vídeos de todos los géneros, para todos los gustos.Deportes - Canje vuelta al cole997.39712159011 +es_ES(Canje vuelta al coleN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A395936115788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ESxZapatillas de balonmano de hombre Adizero Fastcourt 2 adidas +en_GBTo stay one step ahead on indoor courts, you need blink-quick acceleration. These lightweight adidas Adizero Fastcourt shoes help convert fast-thinking to quick feet with a lightweight upper and low-profile Lightstrike midsole that helps you react in an instant. Underneath, the multidirectional outsole has rounded edges for a more natural feel when changing direction.This product is made with Primegreen, a series of high-performance recycled materials. 50% of the upper is recycled content. No virgin polyester.Regular fitLace closure,Lightweight mesh upperBreathable feelDLateral supports and heel lockdown,Lightstrike cushioning +fr_FRPour garder une longueur d'avance sur les terrains indoor, tu dois accélérer rapidement. La chaussure adidas Adizero Fastcourt est un modèle léger, conçu avec une tige légère et une fine semelle intermédiaire Lightstrike qui assure une réactivité optimale. La semelle extérieure multi-directionnelle présente des bords arrondis pour des changements de direction naturels.Ce produit est conçu avec Primegreen, une série de matériaux recyclés haute performance. La tige est faite à 50 % de matériaux recyclés. Sans polyester vierge.&Chaussant standard.(Fermeture à lacets.,Tige légère en mesh."Design respirant.LSoutien latéral et maintien du talon.&Amorti Lightstrike. +es_ESSi quieres ir un paso por delante del rival en pista cubierta, necesitas una aceleración explosiva. Esta zapatilla adidas Adizero Fastcourt presenta una parte superior ligera y una mediasuela Lightstrike que se combinan para ayudarte a reaccionar con la máxima velocidad. La suela multidireccional con bordes redondeados te ofrece una pisada más natural en los cambios de dirección.Este producto se ha fabricado con Primegreen, una combinación de materiales reciclados de alto rendimiento. El 50% de la parte superior se ha confeccionado con materiales reciclados. No contiene poliéster virgen.Este producto está elaborado con Primegreen, una serie de materiales reciclados de alto rendimiento. El 50% de la parte superior es contenido reciclado. Sin poliéster virgen.Ajuste regular$Cierre de cordones>Parte superior de malla livianaParte superior de malla livianaNEED REGRIND %% FOR THIS BULLET^Exaggerated, saw-tooth outsole for bold styling +es_ES,Run Star, reutilizada. +Luce bien y siéntete bien en la última edición del éxito de ventas Run Star Hike. Fabricadas con una parte superior de felpa reciclada en un 88% para aportar calidez y acabadas con cordones 100% reciclados, fijaciones de poliéster reciclado en un 80% y una entresuela Nike Grind reciclada. Con una parte superior de felpa texturizada y detalles de goma moteada, destaca a la vez que defiende el planeta.Zapatilla de plataforma de caña alta, con una parte superior de felpa de una sola pieza, fabricada con un 88% de poliéster reciclado y al menos un 20% de contenido reciclado en pesoCordones de poliéster hilado 100% reciclado y ribetes de poliéster 80% recicladoParche en el tobillo con grabado directo y logotipo Renew Star de poliéster 100% reciclado en el talónzSuela de dientes de sierra exagerados para un estilo atrevidoA44427863123751056CONVERSE +es_ESCONVERSE4893911600071639 +es_ESNPRODUCTOS PARA GENTE DEPORTIVAPROGED SLCALLE JUNDIZ,4.PABELLON 20A,.-01015 VITORIA - ALAVA-ARABA (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeA02046C +es_ESZapatillas casual de mujer Run Star Hike Colección Crater Renew Scrap Punch Alta Converse +es_ESZapatillas casual de mujer Run Star Hike Colección Crater Renew Scrap Punch Alta Converse +en_GB$Run star, renewed.Look good and feel good in the latest edition of the best-selling Run Star Hike. Made with a single-piece 88% recycled felt upper for warmth and finished with 100% recycled laces, 80% recycled polyester bindings, and a %% recycled Nike Grind midsole. With a textured felt upper and speckled rubber details, it stands out while standing up for the planet.High-top platform sneaker, with a single-piece felt upper, made from 88% recycled polyester and at least 20% recycled content by weight100% recycled spun polyester laces and 80% recycled polyester bindingsjDirect deboss ankle patch and 100% recycled polyester6Renew Star logo at heelstay>NEED REGRIND %% FOR THIS BULLET^Exaggerated, saw-tooth outsole for bold styling +es_ES,Run Star, reutilizada. +Luce bien y siéntete bien en la última edición del éxito de ventas Run Star Hike. Fabricadas con una parte superior de felpa reciclada en un 88% para aportar calidez y acabadas con cordones 100% reciclados, fijaciones de poliéster reciclado en un 80% y una entresuela Nike Grind reciclada. Con una parte superior de felpa texturizada y detalles de goma moteada, destaca a la vez que defiende el planeta.Zapatilla de plataforma de caña alta, con una parte superior de felpa de una sola pieza, fabricada con un 88% de poliéster reciclado y al menos un 20% de contenido reciclado en pesoCordones de poliéster hilado 100% reciclado y ribetes de poliéster 80% recicladoParche en el tobillo con grabado directo y logotipo Renew Star de poliéster 100% reciclado en el talónzSuela de dientes de sierra exagerados para un estilo atrevido +calificacion1Acalificacion2Acalificacion4VVcalificacion5AAcalificacion6MO00N276933409037,5 +es_ES37,5E +es_ESEspañol4793600905 +es_ES518171618090Fabricante +Tallapler4twpwa2rdqphm44qlzhmwa2ypwe2kceprh5w3apaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02020-02-19T23:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02020-02-26T23:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-07-28T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseONEa2ynyjkfoo2woqTIMESTAMP02024-05-14T22:00:01.000ZONEa4brnkellmqilc STRING ref antigua oi22Fechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa7jpc7s7go77wi ENTITY{"identifier":"Textil","name":[{"value":"Textil","locale":"es_ES"}],"external_identifier":"392162090","description":[{"value":"Textil","locale":"es_ES"}],"type_lookup":"1633"}ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Goma","name":[{"value":"Goma","locale":"es_ES"}],"external_identifier":"477871090","description":[{"value":"Goma","locale":"es_ES"}],"type_lookup":"1633"}MANYamzex7cmn57eei ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Felpa","name":[{"value":"Felpa","locale":"es_ES"}],"external_identifier":"477865090","description":[{"value":"Felpa","locale":"es_ES"}],"type_lookup":"1633"}{"identifier":"Poliéster reciclado","name":[{"value":"Poliéster reciclado","locale":"es_ES"}],"external_identifier":"391093090","description":[{"value":"Poliéster reciclado","locale":"es_ES"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEaug6jmbvxng2pi ENTITY{"identifier":"Alta","name":[{"value":"Alta","locale":"es_ES"}],"external_identifier":"492722090","description":[{"value":"Alta","locale":"es_ES"}],"type_lookup":"1608"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Casual","name":[{"value":"Casual","locale":"es_ES"}],"external_identifier":"373606090","description":[{"value":"Casual","locale":"es_ES"}],"type_lookup":"1620"}{"identifier":"Zapatillas","name":[{"value":"Zapatillas","locale":"es_ES"}],"external_identifier":"349403090","description":[{"value":"Zapatillas","locale":"es_ES"}],"type_lookup":"1620"}ONEauur46vhpycka4 ENTITY{"identifier":"Deportivas mujer","name":[{"value":"Deportivas mujer","locale":"es_ES"}],"external_identifier":"373605090","description":[{"value":"Deportivas mujer","locale":"es_ES"}],"type_lookup":"1611"}MANYaxr5m2ljibnmui NUMBER2022Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001533092670050"2022-07-28T22:00Z(2020-02-26T23:00:01Z(2020-02-19T23:00:01Z$001082369615651050001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore05008H99299d4c-10a4-485f-b853-428c4e911619 DELETE<2023-09-02T17:20:19.042852759Z4dataloader-mongo-kafka-job62023-09-02T17:20:24.903571Z(mixer-gtin-agr-kfreeHd159c677-5247-4e3e-b12d-2ab34eaf684462023-09-02T17:20:36.534501Z,mixer-gtin-calc-pcsflmH4684b882-eb5e-4af7-a12f-f7ef61da47f862023-09-02T17:20:36.927060Z,mixer-gtin-calc-pcsflmH48676441-54da-4e67-b550-f7e95a91b3ce62023-09-02T22:44:03.764539Z0mixer-product-calc-kfreeHb5c1246d-10c8-4568-b6a4-8539753fe18d<2024-01-19T11:18:33.149210110Z$mixer-xsell-mixtriH503105bc-5900-4a64-98ac-7e93cdfb217062024-01-19T11:18:38.427019Z4mixer-packing-units-mixtriH15f9c9cb-2126-4403-b297-67a5764c8e7b62024-01-19T11:18:50.828336Z.mixer-offer-badge-mixbiH94ab1f87-94f9-4a0e-b58f-d1d35b6ece5a62024-01-19T11:25:59.409174Z.mixer-offer-badge-mixbiHd250ecca-6947-4b28-ae9e-1b818b69ce14(7×cLoffer(A15894910).publish_ends_extendedIVA08IGIC90"2022-09-24T22:00Z +0058000102558935459001137LIBROS DE TEXTO +es_ESLIBROS DE TEXTOCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001025513700580 "2015-07-07T22:00Z2255137005802"2015-07-07T22:00Z97884964415210(2015-07-09T00:49:04Z +es_ESLIBROS TEXTO1 +es_ES Libros274977090 Libros395ML +es_ESml +1.0009788496441521$0000000001405051752401968176567899311056VTP +es_ESVTP +es_ESPrimaria 3999.1149223013 +es_ES Tercero Primaria 12.000 +es_ESLibros de Texto999.906419013 +es_ESLibros de Texto 32.000 +es_ES Libros999.54302013 +es_ES LibrosNNN1 +es_ES Libros274977090 Libros395A15894910 +es_ESPrimaria 3999.1149223013 +es_ES Tercero Primaria 12.000 +es_ESLibros de Texto999.906419013 +es_ESLibros de Texto 32.000 +es_ES Libros999.54302013 +es_ES LibrosNNN2034025 +es_ESVTP +es_ES5ep treboleA15894910899311056VTP +es_ESVTP0238634 +es_ES@DISTRIBUCIONES CIMADEVILLA, S.A.998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de Productos9788496441521 +es_ES5ep trebole +es_ES5ep trebole calificacion1REcalificacion2Ecalificacion3E5calificacion4VVcalificacion5Acalificacion6PE06pler4twpwa2rdqpkcwmvhkxxd52gONEa2wkf4iqk324hsBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-06-29T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-01T03:36:41.000ZONEapruxddhqugapwBOOLEANtrueONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa3aauuktnvama2 ENTITY{"identifier":"30033859","name":[{"value":"VV.AA. VV.AA.","locale":"es_ES"}],"external_identifier":"3175050051","given_name":"VV.AA.","family_name":"VV.AA.","birth_place":[],"death_place":[],"biography":[],"media_objects":[],"normalized_name":"vv.aa.-vv.aa."}ONEa3novp2ls57ixm STRINGR[{"locale":"es_ES","value":"SIN ESTILO"}]ONEa5ej6iwjweshes STRING999ONEacnblp3uq557wk STRING999ONEadizbj7oydkivk STRINGVV.AA._VV.AA._ONEadwyeen33wnwra STRING213ONEangal4rqdmxpse STRINGR[{"locale":"es_ES","value":"SIN ESTILO"}]ONEaogwgan32v4m66 STRINGFVMANYaoyr2i73cpmiu6 ENTITY{"identifier":"Castellano","name":[{"value":"Castellano","locale":"es_ES"}],"external_identifier":"347423090","description":[{"value":"Castellano","locale":"es_ES"}],"type_lookup":"157"}ONEau4wikbtn4ylzk STRING5ep treboleMANYavkyp3speudsm6COMPLEX{"a3lf5jp2cerkrw":[{"identifier":"Asturias","name":[{"value":"Asturias","locale":"es_ES"}],"external_identifier":"1166421090","description":[{"value":"Asturias","locale":"es_ES"},{"value":"Astúrias","locale":"pt_PT"}],"type_lookup":"414"}]}MANY*libros_iss_calculatedCOMPLEX{"name":"VV.AA. VV.AA.","rol":"Autor","grouper":"author","normalize_name_grouper":"author|vv.aa.-vv.aa."}Libros_ISS.SPEC_SECONDARY_TEMPLATE +es_ESVoluminoso348625090Voluminoso +es_ESVoluminoso401$000000000140505175(2022-10-01T03:36:41Z(2022-06-29T22:00:01Z$001025513700580 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hfbd88503-9831-41f7-b4c4-b4de971d475e DELETE<2023-09-02T17:29:28.199678275Z4dataloader-mongo-kafka-job62023-09-02T17:30:39.977175Z(mixer-gtin-agr-kfreeHfb71415b-bb00-4e9f-858b-a6e8ff91c16462023-09-02T17:37:18.384415Z,mixer-gtin-calc-pcsflmH135f76cd-d4dc-48f8-8c22-4231ecd88cc962023-09-02T17:37:19.915396Z,mixer-gtin-calc-pcsflmHb902a025-ecee-453a-8b7c-096ba695f80362023-09-02T22:28:55.245756Z0mixer-product-calc-kfreeH0c1a2dac-50d6-4fb6-9b73-713426d654b9<2024-01-19T11:18:38.333087136Z$mixer-xsell-mixtriH05f6878e-f8fb-4b9b-8914-0647dd79f6ef62024-01-19T11:18:38.562947Z4mixer-packing-units-mixtriHe106ca75-a2ea-404e-be1d-d259f516ec0962024-01-19T11:18:51.011115Z.mixer-offer-badge-mixbiHc86d5017-d087-4a39-8da0-9087610c982e62024-01-19T11:25:59.410372Z.mixer-offer-badge-mixbiHc0b44f49-cbc6-464a-a0f8-d053d589254b(7×cJoffer(A9635752).publish_ends_extendedIVA08IGIC90"2022-09-24T22:00Z +3402900102551530390001626LIBROS DE TEXTO +es_ESLIBROS DE TEXTOCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001025562634029  +es_ES8Restricción libros de texto11493280908Restricción libros de texto +es_ES8Restricción libros de textoSPECIAL_GOOD"2018-02-08T23:00Z97801945699340(2013-07-02T00:48:50Z +es_ES*OXF ENGLISH FOR CAREE1 +es_ES Libros274977090 Libros395ML +es_ESml +0.0009780194569934$0000000001026546252401390797125578936056,OXFORD UNIVERSITY PRES +es_ES.OXFORD UNIVERSITY PRESS +es_ES,Formación Profesional999.1149218013 +es_ES,Formación Profesional 47.000 +es_ESLibros de Texto999.906419013 +es_ESLibros de Texto 32.000 +es_ES Libros999.54302013 +es_ES LibrosNNN1 +es_ES Libros274977090 Libros395A9635752 +es_ES,Formación Profesional999.1149218013 +es_ES,Formación Profesional 47.000 +es_ESLibros de Texto999.906419013 +es_ESLibros de Texto 32.000 +es_ES Libros999.54302013 +es_ES LibrosNNN5574531602020347 +es_ES,OXFORD UNIVERSITY PRES ,- - ()  +es_ES2Finance 1. Student's book +es_ESFinance 1 is suitable for intermediate students studying for a career in the financial industries. Finance 1 gives students the language, information, and skills they will need for a career in these industries, and the preparation required to pass the ICFE exam. The Reading Bank in the middle of the book provides practice in reading and vocabulary skills, using questions in a similar format to the Test of Reading in the ICFE. The Webquest in each unit is a short, practical internet-based task for students to do in class time, or longer more involved tasks to do outside the classroom. Webquest tasks can be linked to other sections in the unit, and range from a simple internet research project, to an instruction to interview someone in their native language, and then write up a summary in English. The 'Professional Skills' feature in each unit covers a range of skills, including making presentations and negotiating, and addresses subjects such as professional ethics in theA96357524851111600029942 +es_ES,EUSKAL KULTURGINTZA SAxCALLE PORTUETXE,88-20018 SAN SEBASTIAN - GIPUZKOA (ESPAñA) 998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de Productos9780194569934 +es_ES2Finance 1. Student's book +es_ES2Finance 1. Student's book +es_ESFinance 1 is suitable for intermediate students studying for a career in the financial industries. Finance 1 gives students the language, information, and skills they will need for a career in these industries, and the preparation required to pass the ICFE exam. The Reading Bank in the middle of the book provides practice in reading and vocabulary skills, using questions in a similar format to the Test of Reading in the ICFE. The Webquest in each unit is a short, practical internet-based task for students to do in class time, or longer more involved tasks to do outside the classroom. Webquest tasks can be linked to other sections in the unit, and range from a simple internet research project, to an instruction to interview someone in their native language, and then write up a summary in English. The 'Professional Skills' feature in each unit covers a range of skills, including making presentations and negotiating, and addresses subjects such as professional ethics in the calificacion1REcalificacion2Ecalificacion3E5calificacion4VVcalificacion5Acalificacion6PE06pler4twpwa2rdqpkcwmvhkxxd52gONEa2wkf4iqk324hsBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-06-14T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-01T05:16:25.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE$MANYa3aauuktnvama2 ENTITY{"identifier":"0092485","name":[{"value":"VARIOS AUTORES","locale":"es_ES"}],"external_identifier":"428577051","family_name":"VARIOS AUTORES","birth_place":[],"death_place":[],"biography":[],"media_objects":[],"normalized_name":"varios-autores"}ONEa3novp2ls57ixm STRINGR[{"locale":"es_ES","value":"SIN ESTILO"}]ONEa4pp5rqvfzxxf6 NUMBER27.6ONEa5ej6iwjweshes STRING999ONEaawxj2frtynidc ENTITY{"identifier":"20180202124914","name":[{"value":"ENGLISH FOR CAREERS","locale":"es_ES"}],"external_identifier":"23799419053"}ONEacnblp3uq557wk STRING999ONEadizbj7oydkivk STRINGVarios autoresONEadwyeen33wnwra STRING249ONEaj6qadcmhrezii NUMBER144ONEajjkwpbdx2sews NUMBER400ONEamtwcchnrdjzfw ENTITY{"identifier":"g","name":[{"value":"g","locale":"es_ES"}],"external_identifier":"347187090","description":[{"value":"g","locale":"es_ES"}],"type_lookup":"206"}ONEangal4rqdmxpse STRINGR[{"locale":"es_ES","value":"SIN ESTILO"}]MANYaoyr2i73cpmiu6 ENTITY{"identifier":"Inglés","name":[{"value":"Inglés","locale":"es_ES"}],"external_identifier":"347433090","description":[{"value":"Inglés","locale":"es_ES"}],"type_lookup":"157"}ONEau4wikbtn4ylzk STRING2Finance 1. Student's bookMANYavkyp3speudsm6COMPLEX9{"a3lf5jp2cerkrw":[{"identifier":"Andalucía","name":[{"value":"Andalucía","locale":"es_ES"}],"external_identifier":"1166419090","description":[{"value":"Andalucía","locale":"es_ES"},{"value":"Andaluzia","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Aragón","name":[{"value":"Aragón","locale":"es_ES"}],"external_identifier":"1166420090","description":[{"value":"Aragón","locale":"es_ES"},{"value":"Aragão","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Asturias","name":[{"value":"Asturias","locale":"es_ES"}],"external_identifier":"1166421090","description":[{"value":"Asturias","locale":"es_ES"},{"value":"Astúrias","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Baleares","name":[{"value":"Baleares","locale":"es_ES"}],"external_identifier":"1166422090","description":[{"value":"Baleares","locale":"es_ES"},{"value":"Baleares","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Cantabria","name":[{"value":"Cantabria","locale":"es_ES"}],"external_identifier":"1166423090","description":[{"value":"Cantabria","locale":"es_ES"},{"value":"Cantábria","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Castilla La Mancha","name":[{"value":"Castilla La Mancha","locale":"es_ES"}],"external_identifier":"1166424090","description":[{"value":"Castilla La Mancha","locale":"es_ES"},{"value":"Castilla La Mancha","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Castilla y León","name":[{"value":"Castilla y León","locale":"es_ES"}],"external_identifier":"1166425090","description":[{"value":"Castilla y León","locale":"es_ES"},{"value":"Castilla y León","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Cataluña","name":[{"value":"Cataluña","locale":"es_ES"}],"external_identifier":"1166426090","description":[{"value":"Cataluña","locale":"es_ES"},{"value":"Catalunha","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Comunidad Valenciana","name":[{"value":"Comunidad Valenciana","locale":"es_ES"}],"external_identifier":"1166428090","description":[{"value":"Comunidad Valenciana","locale":"es_ES"},{"value":"Comunidade Valenciana","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Extremadura","name":[{"value":"Extremadura","locale":"es_ES"}],"external_identifier":"1166429090","description":[{"value":"Extremadura","locale":"es_ES"},{"value":"Extremadura","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Galicia","name":[{"value":"Galicia","locale":"es_ES"}],"external_identifier":"1166430090","description":[{"value":"Galicia","locale":"es_ES"},{"value":"Galicia","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"La Rioja","name":[{"value":"La Rioja","locale":"es_ES"}],"external_identifier":"1166431090","description":[{"value":"La Rioja","locale":"es_ES"},{"value":"La Rioja","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Madrid","name":[{"value":"Madrid","locale":"es_ES"}],"external_identifier":"1166433090","description":[{"value":"Madrid","locale":"es_ES"},{"value":"Madrid","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Murcia","name":[{"value":"Murcia","locale":"es_ES"}],"external_identifier":"1166434090","description":[{"value":"Murcia","locale":"es_ES"},{"value":"Múrcia","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"Navarra","name":[{"value":"Navarra","locale":"es_ES"}],"external_identifier":"1166436090","description":[{"value":"Navarra","locale":"es_ES"},{"value":"Navarra","locale":"pt_PT"}],"type_lookup":"414"},{"identifier":"País Vasco","name":[{"value":"País Vasco","locale":"es_ES"}],"external_identifier":"1166437090","description":[{"value":"País Vasco","locale":"es_ES"},{"value":"País Basco","locale":"pt_PT"}],"type_lookup":"414"}]}ONEavl7kh42fi2dm4 NUMBER21MANYa5n7q7yo7vv4mmCOMPLEX[{"locale":"es_ES","value":[{"aboxfxr6aqfxku":["Finance 1 is suitable for intermediate students studying for a career in the financial industries. Finance 1 gives students the language, information, and skills they will need for a career in these industries, and the preparation required to pass the ICFE exam. The Reading Bank in the middle of the book provides practice in reading and vocabulary skills, using questions in a similar format to the Test of Reading in the ICFE. The Webquest in each unit is a short, practical internet-based task for students to do in class time, or longer more involved tasks to do outside the classroom. Webquest tasks can be linked to other sections in the unit, and range from a simple internet research project, to an instruction to interview someone in their native language, and then write up a summary in English. The 'Professional Skills' feature in each unit covers a range of skills, including making presentations and negotiating, and addresses subjects such as professional ethics in the"]}]}]MANY*libros_iss_calculatedCOMPLEX{"name":"VARIOS AUTORES","rol":"Autor","grouper":"author","normalize_name_grouper":"author|varios-autores"}Libros_ISS.SPEC_SECONDARY_TEMPLATE +es_ESVoluminoso348625090Voluminoso +es_ESVoluminoso401$000000000102654625(2022-10-01T05:16:25Z(2022-06-14T22:00:01Z$001025562634029 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H56ea9e4c-c562-46b6-8ced-09564d25989f DELETE<2023-09-02T17:30:05.293972582Z4dataloader-mongo-kafka-job62023-09-02T17:32:00.945935Z(mixer-gtin-agr-kfreeH0aa18f71-165f-4dfd-acf9-e5357c80340862023-09-02T17:37:01.112864Z,mixer-gtin-calc-pcsflmH40d9ea08-409c-42e1-a20b-1780b567a80862023-09-02T17:37:01.617122Z,mixer-gtin-calc-pcsflmH503777b4-3fdf-4ebb-b960-a308c6c2dbf962023-09-02T22:16:26.973314Z0mixer-product-calc-kfreeH6d7e954e-4f26-4bf1-8179-0279121494f1<2024-01-19T11:18:01.614363702Z$mixer-xsell-mixtriH1e3891d0-7d6e-4cc7-ab5a-29e58cf47cd762024-01-19T11:18:01.853667Z4mixer-packing-units-mixtriH3d017fad-64f1-4ee9-ba72-5a427c22d2f762024-01-19T11:18:50.620735Z.mixer-offer-badge-mixbiH40c2b9c4-c645-4383-94fa-2691facf360562024-01-19T11:25:59.412546Z.mixer-offer-badge-mixbiH2507b9e5-6cfe-4827-a352-1b408804f6e9(7×cLoffer(A41171555).publish_ends_extendedIVA02IGIC91 +00952001054340270173001100COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001054310000952038&includeAsWebNovelty +es_ESNovedadDVD"2021-09-19T22:00Z8445110281352 +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa +es_ESRosa347700090 +es_ESRosa5985060542019 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png +es_ESCOLOR_ROSA +es_ESColor RosaRosa +es_ESRosa0(2021-09-20T15:22:23Z +es_ESPANT_AUSTIN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008445110281352$000001518571840038TRADICIONAL +es_ESCOLOR_ROSA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png2401811907782147145056DESIGUALmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/0/00001269350/00001269350419mM1011.jpg +es_ESDesigual +es_ES6Pantalones anchos y palazzo999.39090693013 +es_ES6Pantalones anchos y palazzo +2.000 +es_ESPantalones999.39090691013 +es_ESPantalones 20.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41171555 +es_ES6Pantalones anchos y palazzo999.39090693013 +es_ES6Pantalones anchos y palazzo +2.000 +es_ESPantalones999.39090691013 +es_ESPantalones 20.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0022144 +es_ESABASIC, S.A. +es_ESTPantalón de mujer encaje y transparencias +es_ESPantalón confeccionado en encaje que tiene transparencias desde la rodilla. El bajo sigue la forma del encaje y tiene pequeños flecos. Un pantalón fresco y ligero.A41171555147145056DESIGUAL +es_ESDESIGUAL15134011600022144 +es_ESABASIC, S.A.CALLE PASSEIG DEL MARE NOSTRUM,15-08039 BARCELONA - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize22SWPW14 +es_ESTPantalón de mujer encaje y transparencias +es_ESTPantalón de mujer encaje y transparencias +es_ESPantalón confeccionado en encaje que tiene transparencias desde la rodilla. El bajo sigue la forma del encaje y tiene pequeños flecos. Un pantalón fresco y ligero. calificacion1Acalificacion2Acalificacion3RIcalificacion4VVcalificacion5Bcalificacion62100N47927409038 +es_ES38E +es_ESEspañol479443090S +es_ESS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-10T04:23:31.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-11T04:23:31.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-02-17T05:03:42.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar en agua fría","name":[{"value":"Lavar en agua fría","locale":"es_ES"}],"external_identifier":"349555090","description":[{"value":"Lavar en agua fría","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado delicado","name":[{"value":"Planchado delicado","locale":"es_ES"}],"external_identifier":"351060090","description":[{"value":"Planchado delicado","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Planchado delicado","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201606/28/23309_1_.png","size":"small"}],"description":[{"value":"Planchado delicado","locale":"es_ES"}],"identifier":"23309","name":[{"value":"PLANCHADO_DELICADO","locale":"es_ES"}],"external_identifier":"12615474054"}}{"identifier":"Lavado en seco","name":[{"value":"Lavado en seco","locale":"es_ES"}],"external_identifier":"484879090","description":[{"value":"Lavado en seco","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Ornamental","name":[{"value":"Ornamental","locale":"es_ES"}],"external_identifier":"25550605090","description":[{"value":"Ornamental","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pantalones palazzo y anchos","name":[{"value":"Pantalones palazzo y anchos","locale":"es_ES"}],"external_identifier":"32762500090","description":[{"value":"Pantalones palazzo y anchos","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}ONEamhxjtd3ly77cm ENTITY{"identifier":"Alta","name":[{"value":"Alta","locale":"es_ES"}],"external_identifier":"32841925090","description":[{"value":"Alta","locale":"es_ES"}],"type_lookup":"2646090"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":63,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":37}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518571840038(2022-02-17T05:03:42Z(2022-09-11T04:23:31Z(2022-09-10T04:23:31Z$001054310000952038001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore038H87e5d01d-ed07-4912-8ccf-ce2ed9b2a8ce DELETE<2023-09-02T17:21:07.658285993Z4dataloader-mongo-kafka-job62023-09-02T17:21:18.441416Z(mixer-gtin-agr-kfreeH1ccbe8f0-ffaa-4049-8811-66fd3a34882f62023-09-02T17:21:26.211276Z,mixer-gtin-calc-pcsflmHc35eb311-339a-48b5-bb1f-e178983781d962023-09-02T17:21:28.612571Z,mixer-gtin-calc-pcsflmH72a29ab1-afcc-4b05-ac3c-50fdccca5e7862023-09-02T21:53:05.654518Z0mixer-product-calc-kfreeH8a60be63-568f-49a6-8f38-ba4fbfc3cdfc<2024-01-19T11:18:02.028883772Z$mixer-xsell-mixtriH1bea3f8f-5d63-494f-9da0-8d70b1efe6a962024-01-19T11:18:02.146986Z4mixer-packing-units-mixtriH973dbddd-c681-427e-8cec-40d1d713681162024-01-19T11:18:50.627840Z.mixer-offer-badge-mixbiHa59a85a7-4cf9-4408-b2f2-64b5fd36f80362024-01-19T11:25:59.413182Z.mixer-offer-badge-mixbiH7c1b16f3-e858-4d2b-895d-9521187da712(7×cIVA02IGIC91 +2346100102023-04-24T18:15:18.597Z019740819110001107COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001019710723461040"2021-05-24T22:00Z4065423725127 +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa +es_ESRosa347700090 +es_ESRosa5985060542019 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png +es_ESCOLOR_ROSA +es_ESColor RosaRosa +es_ESRosa0(2021-11-25T15:36:41Z +es_ESSUDADERA M/L +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004065423725127$000001513975850040TRADICIONAL +es_ESCOLOR_ROSA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png2401799239332123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESSudaderas999.14620000013 +es_ESSudaderas +7.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A398879365788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ESTSudadera de mujer Trefoil adidas Originals +en_GBGo all in. Have fun with colour in this Adicolor sweatshirt. An old-school Trefoil logo keeps this pullover legit. Soft, all-cotton French terry feels plush. Comfy always wins. +es_ESPon un toque de color a tu look. Esta sudadera presenta un diseño clásico con el logotipo del trébol en la parte frontal. Su tejido de felpa de algodón es muy cómodo y suave al tacto.A39887936123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize HE9536 +es_ESTSudadera de mujer Trefoil adidas Originals +es_ESTSudadera de mujer Trefoil adidas Originals +en_GBGo all in. Have fun with colour in this Adicolor sweatshirt. An old-school Trefoil logo keeps this pullover legit. Soft, all-cotton French terry feels plush. Comfy always wins. +es_ESPon un toque de color a tu look. Esta sudadera presenta un diseño clásico con el logotipo del trébol en la parte frontal. Su tejido de felpa de algodón es muy cómodo y suave al tacto. +calificacion1Acalificacion2Acalificacion4VVcalificacion5ADcalificacion6MO00N47930109040 +es_ES40E +es_ESEspañol47930109040 +es_ES40477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02021-11-22T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-11-23T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-11-22T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"347714090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"485392090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"},{"value":"Algodão","locale":"pt_PT"},{"value":"Coton","locale":"fr_FR"},{"value":"Cotton","locale":"en_GB"},{"value":"Cotone","locale":"it_IT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001513975850040"2021-11-22T23:00ZDVD"2021-11-23T23:00Z"2021-11-22T23:00Z$001019710723461040001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore040H8f784f6f-83ae-41de-8185-32e7d6334cca DELETE<2023-09-02T17:37:15.314924451Z4dataloader-mongo-kafka-job62023-09-02T17:50:34.522095Z(mixer-gtin-agr-kfreeH17ca151f-7a45-4b45-8b31-21ae0a2e6a7c62023-09-02T18:02:17.315858Z,mixer-gtin-calc-pcsflmHb7ee95f0-c9a2-4582-b900-6151fe9fcbad62023-09-02T18:02:30.114223Z,mixer-gtin-calc-pcsflmH071cfae7-383b-4599-a862-2a83fd22c97862023-09-03T03:07:27.102568Z0mixer-product-calc-kfreeHc87019cd-9c42-437d-84ba-53c8eb28bb07<2024-01-19T11:18:48.270145700Z$mixer-xsell-mixtriHe1733fbc-14da-46c8-9d43-60246a11d5b062024-01-19T11:18:48.396553Z4mixer-packing-units-mixtriH09de8ec5-62fb-45c4-811f-792266e0e24662024-01-19T11:18:50.631718Z.mixer-offer-badge-mixbiH2651110b-e0be-4230-a7b0-0f5ef615dae362024-01-19T11:25:59.413780Z.mixer-offer-badge-mixbiH7467ba6a-cd92-49f9-965a-c64342f3159d(7×cLoffer(A42522372).publish_ends_extendedIVA02IGIC91 +03838001086541873769001866(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001086586603838005&includeAsWebNovelty +es_ESNovedadDVD"2022-01-20T23:00Z3605443541577Blancos +es_ESBlancosBlancos +es_ESBlancos +Crudo +es_ES +Crudo353271090 +es_ES +Crudo599789054 +52735 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___52735O1.png +es_ESCOLOR_CRUDO +es_ESColor Crudo +Crudo +es_ES +Crudo0(2022-03-11T17:12:30Z +es_ESBERMUDAS156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003605443541577$000001524710850005TRADICIONAL +es_ESCOLOR_CRUDO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___52735O1.png2401825636456211712056IKKSmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/34/9/00001269349/00001269349881mM1011.jpg +es_ESIKKS +es_ESBermudas999.39089916013 +es_ESBermudas 15.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42522372 +es_ESBermudas999.39089916013 +es_ESBermudas 15.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN0340950 +es_ES2IKKS SPORTSWEAR SPAIN S.A +es_ESPBermudas de niño con parche y cinturón +es_ES5 bolsillos, parche rayo delante. Cinturón en contraste, bordados delante y detrás. Cintura ajustable, cierre con cremallera y corchete... +pt_PT.A42522372211712056IKKS +es_ESIKKS0340950 +es_ES2IKKS SPORTSWEAR SPAIN S.A998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeXU25083.12 +es_ESPBermudas de niño con parche y cinturón +es_ESPBermudas de niño con parche y cinturón +es_ES5 bolsillos, parche rayo delante. Cinturón en contraste, bordados delante y detrás. Cintura ajustable, cierre con cremallera y corchete... +pt_PT. +calificacion1Acalificacion2Acalificacion3M1calificacion4VVcalificacion5VV00N4793610905 Años +es_ES5 AñosE +es_ESEspañol4793610905 Años +es_ES5 Años477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRINGReacondicionados - Informática999.19641845013 +es_ES0Ordenadores y accesorios +3.000 +es_ES>Reacondicionados - Electrónica999.19641834013 +es_ES Reacondicionados 97.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNNN56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A45169883 +es_ESOrdenadores999.19641846013 +es_ESOrdenadores +1.000 +es_ES>Reacondicionados - Informática999.19641845013 +es_ES0Ordenadores y accesorios +3.000 +es_ES>Reacondicionados - Electrónica999.19641834013 +es_ES Reacondicionados 97.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNNN5097371600303321 +es_ES*ESPRINET IBERICA, SLUCALLE OSCA,2 PLAZA-CAMPUS 3.84 NAVE,I-50197 ZARAGOZA - ZARAGOZA (ESPAñA)  +es_ESConvertible 2 en 1 ASUS VivoBook Flip 14 TP470EA-EC199T, i7, 16GB, 512GB SSD, 14", W10 (Reacondicionado grado A) +es_ESLos reacondicionados grados A tienen algún desperfecto físico que no es apreciable a simple vista. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.*Embalaje deteriorado.VivoBook Flip 14 es un portátil convertible lleno de personalidad, con un elegante acabado en plata y una tecla Enter de color bloqueado con bordes y texto amarillos. Una robusta bisagra de 360º sostiene la pantalla firmemente en cualquier ángulo, lo que le brinda la flexibilidad de usar el VivoBook Flip 14 como un portátil tradicional, una tableta o algo intermedio.A45169883130480056ASUS +es_ESASUS5097371600303321 +es_ES*ESPRINET IBERICA, SLUCALLE OSCA,2 PLAZA-CAMPUS 3.84 NAVE,I-50197 ZARAGOZA - ZARAGOZA (ESPAñA) 998.00099 +es_ES*Ordenadores portátil998.00081 +es_ESInformática998 +es_ES@Jerarquía de Ficha de Productos +años +es_ES +años +3.000S102TP470EA-EC1 +es_ESConvertible 2 en 1 ASUS VivoBook Flip 14 TP470EA-EC199T, i7, 16GB, 512GB SSD, 14", W10 (Reacondicionado grado A)TP470EA-EC199T +es_ESConvertible 2 en 1 ASUS VivoBook Flip 14 TP470EA-EC199T, i7, 16GB, 512GB SSD, 14", W10 (Reacondicionado grado A) +es_ESLos reacondicionados grados A tienen algún desperfecto físico que no es apreciable a simple vista. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.*Embalaje deteriorado.VivoBook Flip 14 es un portátil convertible lleno de personalidad, con un elegante acabado en plata y una tecla Enter de color bloqueado con bordes y texto amarillos. Una robusta bisagra de 360º sostiene la pantalla firmemente en cualquier ángulo, lo que le brinda la flexibilidad de usar el VivoBook Flip 14 como un portátil tradicional, una tableta o algo intermedio. calificacion1C1calificacion2Acalificacion3E5calificacion4VVcalificacion5EScalificacion63300Npf3rdpmhdose26pler4twpwa2rdqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-10-03T10:49:36.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-22T02:56:09.000ZONEakzd7vzeui6lmu STRINGPONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-10-18T10:18:27.000ZONEate3liesiuooycBOOLEANtrueMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}ONEazravcn5thdy6eTIMESTAMP02022-10-03T10:49:36.000ZMANYaqundqcyqbyf5mTIMESTAMP02023-01-24T05:38:55.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEJONEa2m23xrd2ttqua NUMBER16ONEa3cov7am5kqzpi ENTITY{"identifier":"GHz","name":[{"value":"GHz","locale":"es_ES"}],"external_identifier":"347546090","description":[{"value":"GHz","locale":"es_ES"}],"type_lookup":"202"}ONEa52nalwdaup62o ENTITY{"identifier":"\"","name":[{"value":"\"","locale":"es_ES"}],"external_identifier":"347404090","description":[{"value":"\"","locale":"es_ES"}],"type_lookup":"204"}ONEa5tmgl2nk6vzg4 ENTITY {"identifier":"MB","name":[{"value":"MB","locale":"es_ES"}],"external_identifier":"347547090","description":[{"value":"MB","locale":"es_ES"}],"type_lookup":"199","glossary":{"term":[{"value":"MB (Megabyte)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Unidad de medición de memoria equivalente a 1.024 kilobytes. La capacidad de almacenamiento de las tarjetas de memoria flash puede especificarse en MB. No debe confundirse con el Mb (megabit): 1 byte son 8 bits.","locale":"es_ES"}],"identifier":"13040","name":[{"value":"MB_(MEGABYTE)","locale":"es_ES"}],"external_identifier":"597126054"}}ONEa5w3mljwesyqjc ENTITY{"identifier":"Iris Xe","name":[{"value":"Iris Xe","locale":"es_ES"}],"external_identifier":"36589958090","description":[{"value":"Iris Xe","locale":"es_ES"}],"type_lookup":"667"}ONEa7ppo5pauwtpa4 ENTITY{"identifier":"GHz","name":[{"value":"GHz","locale":"es_ES"}],"external_identifier":"347546090","description":[{"value":"GHz","locale":"es_ES"}],"type_lookup":"202"}ONEaa3mkeetvctl5k NUMBER1.87ONEabgd4pscaglu6o NUMBER2.8ONEackff4s43zawxq ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}MANYadk7yv7bv56rfs STRING[{"locale":"es_ES","value":["Altavoz y micrófono array integrados. SonicMaster. Audio by ICEpower"]}]MANYaecynrz3pqpqho ENTITY{"identifier":"Pantalla táctil","name":[{"value":"Pantalla táctil","locale":"es_ES"}],"external_identifier":"12850154090","description":[{"value":"Pantalla táctil","locale":"es_ES"}],"type_lookup":"1708"}ONEaeru2ndkwoh3cg ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}ONEaf4rzt3pxxadek ENTITY{"identifier":"1165G7","name":[{"value":"1165G7","locale":"es_ES"}],"external_identifier":"36589955090","description":[{"value":"1165G7","locale":"es_ES"}],"type_lookup":"589"}ONEag5bcddr6k5iua NUMBER22ONEagtshfuxpptieo ENTITY{"identifier":"LPDDR4X","name":[{"value":"LPDDR4X","locale":"es_ES"}],"external_identifier":"36989225090","description":[{"value":"LPDDR4X","locale":"es_ES"}],"type_lookup":"437"}MANYajneqn4uttux3u ENTITY{"identifier":"No tiene","name":[{"value":"No tiene","locale":"es_ES"}],"external_identifier":"8229343090","description":[{"value":"No tiene","locale":"es_ES"}],"type_lookup":"1707"}ONEajzs3pds77jrs6 ENTITY{"identifier":"Intel","name":[{"value":"Intel","locale":"es_ES"}],"external_identifier":"22000486090","description":[{"value":"Intel","locale":"es_ES"}],"type_lookup":"666090"}ONEak7mvbyllv276m NUMBER 1080.0MANYakfne26osto34y ENTITY{"identifier":"HDMI 1.4","name":[{"value":"HDMI 1.4","locale":"es_ES"}],"external_identifier":"11895298090","description":[{"value":"HDMI 1.4","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"Jack 3,5mm (Combo)","name":[{"value":"Jack 3,5mm (Combo)","locale":"es_ES"}],"external_identifier":"10941992090","description":[{"value":"Jack 3,5mm (Combo)","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"DC-in Jack","name":[{"value":"DC-in Jack","locale":"es_ES"}],"external_identifier":"11922664090","description":[{"value":"DC-in Jack","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"USB 2.0 tipo A","name":[{"value":"USB 2.0 tipo A","locale":"es_ES"}],"external_identifier":"2969620090","description":[{"value":"USB 2.0 tipo A","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"USB 3.2 Gen 1 Tipo A","name":[{"value":"USB 3.2 Gen 1 Tipo A","locale":"es_ES"}],"external_identifier":"33279042090","description":[{"value":"USB 3.2 Gen 1 Tipo A","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"Thunderbolt 4","name":[{"value":"Thunderbolt 4","locale":"es_ES"}],"external_identifier":"37048655090","description":[{"value":"Thunderbolt 4","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"Lector de tarjetas Micro SD","name":[{"value":"Lector de tarjetas Micro SD","locale":"es_ES"}],"external_identifier":"188722090","description":[{"value":"Lector de tarjetas Micro SD","locale":"es_ES"}],"type_lookup":"171"}ONEalpw3us43jr6k6 ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}ONEankuorel7ixqjm NUMBER14ONEaonvymhgablo3m NUMBER4.7MANYaqaggaynxxsnow NUMBER1111111MANYashkcrfkdl56puCOMPLEX[{"locale":"es_ES","value":[{"a5v2ytqne2eemg":"Más información","aqubemlsze7yvo":["Pantalla 250nits/Glossy display/NTSC: 45%/Táctil","Cámara 720p HD","Batería 42WHrs, 3S1P, 3-cell Li-ion"]}]}]ONEasvc6ecvr5dnvm NUMBER1.5ONEavjgyfos7t4lo6 NUMBER 1920.0ONEavmpnzat6h2hie ENTITY{"identifier":"Full HD","name":[{"value":"Full HD","locale":"es_ES"}],"external_identifier":"21515039090","description":[{"value":"Full HD","locale":"es_ES"}],"type_lookup":"599"}ONEavzr66c5qb2jio ENTITY{"identifier":"GB","name":[{"value":"GB","locale":"es_ES"}],"external_identifier":"347549090","description":[{"value":"GB","locale":"es_ES"}],"type_lookup":"199","glossary":{"term":[{"value":"GB (Gigabyte)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Unidad de medida de capacidad de almacenamiento como, por ejemplo, en una memoria interna, un discos duro o una tarjeta de memoria.","locale":"es_ES"}],"identifier":"11520","name":[{"value":"GB_(GIGABYTE)","locale":"es_ES"}],"external_identifier":"596940054"}}ONEawzwd4lq44lsr4 ENTITY {"identifier":"píxeles","name":[{"value":"píxeles","locale":"es_ES"}],"external_identifier":"347402090","description":[{"value":"píxeles","locale":"es_ES"}],"type_lookup":"209","glossary":{"term":[{"value":"Píxel","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Es el nombre con el que se denomina al elemento más pequeño de una imagen digital. La resolución de una imagen o de una pantalla se indica por número de píxeles. Cuanto mayor es el número de píxeles, más alta es la definición.","locale":"es_ES"}],"identifier":"14039","name":[{"value":"PIXEL","locale":"es_ES"}],"external_identifier":"597235054"}}ONEaxvp66vghi4tbu ENTITY{"identifier":"Wi-Fi 6, 802.11ax","name":[{"value":"Wi-Fi 6, 802.11ax","locale":"es_ES"}],"external_identifier":"32686500090","description":[{"value":"Wi-Fi 6, 802.11ax","locale":"es_ES"}],"type_lookup":"185"}ONEaxzcsamo3gs3h4 ENTITY{"identifier":"Windows 10","name":[{"value":"Windows 10","locale":"es_ES"}],"external_identifier":"9371727090","description":[{"value":"Windows 10","locale":"es_ES"}],"type_lookup":"175"}ONEaycuk4kakqbkci NUMBER12MANYayuchmjhgwmmxmCOMPLEX {"alxtskjpxwjlzk":512,"a75pvtgpgznk72":[{"identifier":"SSD","name":[{"value":"SSD","locale":"es_ES"}],"external_identifier":"8229270090","description":[{"value":"SSD","locale":"es_ES"},{"value":"SSD","locale":"pt_PT"}],"type_lookup":"1706"}],"an67k77mgc7z64":{"identifier":"GB","name":[{"value":"GB","locale":"es_ES"}],"external_identifier":"347549090","description":[{"value":"GB","locale":"en_GB"},{"value":"GB","locale":"es_ES"},{"value":"GB","locale":"fr_FR"},{"value":"GB","locale":"pt_PT"}],"type_lookup":"199","glossary":{"term":[{"value":"GB (Gigabyte)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Unidad de medida de capacidad de almacenamiento como, por ejemplo, en una memoria interna, un discos duro o una tarjeta de memoria.","locale":"es_ES"}],"identifier":"11520","name":[{"value":"GB_(GIGABYTE)","locale":"es_ES"}],"external_identifier":"596940054"}}}ONEaz7oi6rgu6myka NUMBER32.4ONEaz7oqq44v7qfl4 ENTITY{"identifier":"Intel Core i7","name":[{"value":"Intel Core i7","locale":"es_ES"}],"external_identifier":"478228090","description":[{"value":"Intel Core i7","locale":"es_ES"}],"type_lookup":"169"}ONEazbzzcsmi2hij6 ENTITY{"identifier":"5.0","name":[{"value":"5.0","locale":"es_ES"}],"external_identifier":"24888103090","description":[{"value":"5.0","locale":"es_ES"}],"type_lookup":"185"}ONEazdfu4pf2dila4 STRINGx0Ordenadores_Portatil_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000153593388(2022-10-18T10:18:27Z(2022-10-22T02:56:09Z(2022-10-03T10:49:36Z +es_ESGrado A32681226090Grado A +es_ESGrado A2643090$001054715295553 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hef7cdd79-7c62-497f-b48e-be4a67c04bf4 DELETE<2023-09-02T17:33:22.383737012Z4dataloader-mongo-kafka-job62023-09-02T17:41:51.652427Z(mixer-gtin-agr-kfreeHe34b4c02-bd0a-4d55-bfb8-a5ddb1edb85762023-09-02T17:56:16.303954Z,mixer-gtin-calc-pcsflmHa8ad021f-f8b7-4480-b2a0-6c1483f2522362023-09-02T17:56:16.533211Z,mixer-gtin-calc-pcsflmHd7a3ba73-6c42-4a76-82a4-c2b7b3f289bc62023-09-02T22:44:28.446821Z0mixer-product-calc-kfreeH4919066a-ce0a-400f-a9a0-050b8fecf15d<2024-01-19T11:18:49.914050526Z$mixer-xsell-mixtriHb2c2b974-88d1-410d-b125-398c8420251d62024-01-19T11:18:49.968049Z4mixer-packing-units-mixtriH2bbf5074-09fc-49c6-8c7d-71877f1e986862024-01-19T11:18:50.823946Z.mixer-offer-badge-mixbiHeee8afb5-a453-46be-9ea1-9f7741723d2462024-01-19T11:25:59.490165Z.mixer-offer-badge-mixbiH97fa1ab7-10cb-483b-aefa-901bdbab2993(7×c,7ǻmf! Loffer(A41076610).publish_ends_extendedIVA02IGIC91 +00381001034040700120001301COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001034030100381046&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31820072090 +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31855841054 +11935 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png +es_ESFCERTIFICACION_OEKO-TEX_STANDARD_100 +es_ESHCertificación Oeko-tex Standard 100 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png002 +es_ESHCertificación Oeko-tex Standard 1008SUSTAINABILITY_MANUFACTURING +es_ESCertificado que garantiza que el producto tiene contenido reciclado, al tiempo que verifica las buenas prácticas sociales y medioambientales.31820053090 +es_ESCertificado que garantiza que el producto tiene contenido reciclado, al tiempo que verifica las buenas prácticas sociales y medioambientales.31845095054 +30859 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202103/03/30859_3_.png +es_ES2RECICLADO_CERTIFICADO_GRS +es_ES2Reciclado certificado GRS +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202103/03/30859_3_.png003 +es_ES2Reciclado certificado GRS:SUSTAINABILITY_CLOSING_CIRCLE"2021-09-09T22:00Z7613138563687 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2021-11-15T11:07:31Z +es_ES*BRAGA CON ESTAMPADO A158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0007613138563687$000001518227660046TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401811228726161822056TRIUMPHmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/7/00001269357/00001269357562mM1011.jpg +es_ESTriumph +es_ES +Baño997.38153216011 +es_ES +Baño +7.000 +es_ESModa Mujer997.38150773011 +es_ESModa Mujer +5.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ES Bragas de bikini999.39089969013 +es_ES Bragas de bikini +3.000 +es_ESBikinis999.39089965013 +es_ESBikinis +8.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41076610 +es_ES Bragas de bikini999.39089969013 +es_ES Bragas de bikini +3.000 +es_ESBikinis999.39089965013 +es_ESBikinis +8.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN4874811600052977 +es_ES6TRIUMPH INTERNACIONAL, S.A.CALLE SANTA LEONOR, 65.EDIF.E.2 PLAN,..-28037 PQ.EMP.AVALON.MADRID - MADRID (ESPAñA)  +es_ESHBraga de bikini con estampado animal +es_ESnBraga con estampado animal fondo negro y ajuste lateralA41076610161822056TRIUMPH +es_ESTRIUMPH4874811600052977 +es_ES6TRIUMPH INTERNACIONAL, S.A.CALLE SANTA LEONOR, 65.EDIF.E.2 PLAN,..-28037 PQ.EMP.AVALON.MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize10207967 +es_ESHBraga de bikini con estampado animal +es_ESHBraga de bikini con estampado animal +es_ESnBraga con estampado animal fondo negro y ajuste lateral +calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5AH00N47933909046 +es_ES46E +es_ESEspañol47933909046 +es_ES46477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-03T00:51:06.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-04T00:51:06.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-03-02T06:25:58.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a mano","name":[{"value":"Lavar a mano","locale":"es_ES"}],"external_identifier":"347780090","description":[{"value":"Lavar a mano","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Lavar a mano","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201301/25/___11516O1.png","size":"small"}],"description":[{"value":"Lavar a mano","locale":"es_ES"}],"identifier":"11516","name":[{"value":"LAVAR_A_MANO","locale":"es_ES"}],"external_identifier":"596937054"}}{"identifier":"No usar blanqueante","name":[{"value":"No usar blanqueante","locale":"es_ES"}],"external_identifier":"484894090","description":[{"value":"No usar blanqueante","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No planchar","name":[{"value":"No planchar","locale":"es_ES"}],"external_identifier":"350554090","description":[{"value":"No planchar","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No Planchar","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___840O1.png","size":"small"}],"description":[{"value":"No Planchar","locale":"es_ES"}],"identifier":"840","name":[{"value":"NO_PLANCHAR","locale":"es_ES"}],"external_identifier":"600047054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Animal Print","name":[{"value":"Animal Print","locale":"es_ES"}],"external_identifier":"9338932090","description":[{"value":"Animal Print","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bragas de bikini","name":[{"value":"Bragas de bikini","locale":"es_ES"}],"external_identifier":"12873128090","description":[{"value":"Bragas de bikini","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Bikinis","name":[{"value":"Bikinis","locale":"es_ES"}],"external_identifier":"8970133090","description":[{"value":"Bikinis","locale":"es_ES"}],"type_lookup":"1599"}ONEarte4uoeu4rkhe ENTITY{"identifier":"Braga con lazo","name":[{"value":"Braga con lazo","locale":"es_ES"}],"external_identifier":"2696252090","description":[{"value":"Braga con lazo","locale":"es_ES"}],"type_lookup":"2506"}ONEastcg34k65osv2 STRING[{"locale":"pt_PT","value":"Charm Elegance"},{"locale":"es_ES","value":"Charm Elegance"}]MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":77,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}},{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"adbyfb4jfvuv5k":23,"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518227660046(2022-03-02T06:25:58Z(2022-10-04T00:51:06Z(2022-10-03T00:51:06Z$001034030100381046001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore046H76b51608-c0d9-48e8-80ea-6dfea790400f DELETE<2023-09-02T17:29:59.309440750Z4dataloader-mongo-kafka-job62023-09-02T17:31:51.713914Z(mixer-gtin-agr-kfreeH7a8d060b-389c-411f-ad7e-2748c525ad8962023-09-02T17:41:16.308571Z,mixer-gtin-calc-pcsflmH1d0a4f16-3723-4af8-83d9-b5b8970fdf7e62023-09-02T17:41:16.922197Z,mixer-gtin-calc-pcsflmH9dd3224a-bed4-433f-9896-5d4b30039b9362023-09-02T22:35:12.664078Z0mixer-product-calc-kfreeH61f1804e-b01c-44fe-b2e2-96d934f12de3<2024-01-19T11:18:49.920137020Z$mixer-xsell-mixtriH36867dbc-9cd5-42fe-b14e-e88c7dce933362024-01-19T11:18:50.069514Z4mixer-packing-units-mixtriH85665d1a-d0b8-4f00-931b-4ad7e088131e62024-01-19T11:18:50.824658Z.mixer-offer-badge-mixbiH4365b2c6-6abd-4509-9d1e-f76c83f088f162024-01-19T11:25:59.491082Z.mixer-offer-badge-mixbiHc440ccca-f783-489e-92b8-2daa14e2f473(7×cIVA02IGIC92 +3709800102023-02-23T06:16:27.950Z028532798289001152COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001028515237098  +es_ES8Restricción Reacondicionado161226080908Restricción Reacondicionado +es_ES8Restricción ReacondicionadoSPECIAL_GOOD +es_ESInternet1229735090Internet +es_ESInternet(2023-01-24T02:04:27ZDVD"2019-09-22T22:00Z2285152370982 +Plata +es_ES +Plata +Plata +es_ES +Plata +Plata +es_ES +Plata344764090 +es_ES +Plata596743054 +10148 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20110223/___10148O2.png +es_ESCOLOR_PLATA +es_ESColor Plata +Plata +es_ES +Plata0(2019-10-25T11:28:43Z +es_ES*IMAC 27/3.5QC/8GB/1TB +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401739821085$000000000149045292TRADICIONAL +es_ESCOLOR_PLATA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20110223/___10148O2.png2401739821085124603056 +Apple +es_ES +Apple +es_ESOrdenadores999.19641846013 +es_ESOrdenadores +1.000 +es_ES>Reacondicionados - Informática999.19641845013 +es_ES0Ordenadores y accesorios +3.000 +es_ES>Reacondicionados - Electrónica999.19641834013 +es_ES Reacondicionados 97.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A323426460904813 +es_ES@APPLE DISTRIBUTION INTERNATIONAL +es_ESApple iMac 27 Pantalla Retina MNE92Y (Reacondicionado casi a estrenar), i5, 8 GB, 1 TB, Radeon Pro 575 4 GB +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.Ordenador Sobremesa Apple iMac MNE92Y Pantalla Retina 27'' Intel Core i5.Ser un ordenador de mesa deslumbrante en todos los sentidos. Ese ha sido siempre el objetivo del iMac. Y ahora, con procesadores nuevos, lo último en gráficos y en almacenamiento, conexiones ultrarrápidas y la pantalla Retina más luminosa de su historia, cumple la misión con creces. El iMac ha vuelto y su estrella brilla cada vez más.A32342646124603056 +APPLE +es_ES +APPLE5448901600904813 +es_ES@APPLE DISTRIBUTION INTERNATIONALCALLE LG HOLLY INDUSTRIAL STATE,..- HOLLYHILL, CORK - (ITALIA) 998.00099 +es_ES*Ordenadores portátil998.00081 +es_ESInformática998 +es_ES@Jerarquía de Ficha de Productos +años +es_ES +años +3.000180MNEA2Y/A +es_ESApple iMac 27 Pantalla Retina MNE92Y (Reacondicionado casi a estrenar), i5, 8 GB, 1 TB, Radeon Pro 575 4 GBMNE92Y/A +es_ESApple iMac 27 Pantalla Retina MNE92Y (Reacondicionado casi a estrenar), i5, 8 GB, 1 TB, Radeon Pro 575 4 GB +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.Ordenador Sobremesa Apple iMac MNE92Y Pantalla Retina 27'' Intel Core i5.Ser un ordenador de mesa deslumbrante en todos los sentidos. Ese ha sido siempre el objetivo del iMac. Y ahora, con procesadores nuevos, lo último en gráficos y en almacenamiento, conexiones ultrarrápidas y la pantalla Retina más luminosa de su historia, cumple la misión con creces. El iMac ha vuelto y su estrella brilla cada vez más. calificacion1Acalificacion2Ocalificacion3E5calificacion4VVcalificacion5EScalificacion6WW065pf3rdpmhdose26pler4twpwa2rdqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-10-31T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-11-01T23:00:00.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02019-10-24T11:31:00.000ZONEate3liesiuooycBOOLEANtrueMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}ONEazravcn5thdy6eTIMESTAMP02019-10-31T08:15:58.000ZMANYaqundqcyqbyf5mTIMESTAMP02023-01-24T02:04:27.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEJONEa2m23xrd2ttqua NUMBER8ONEa2v2iuyk5vvwqg NUMBER8ONEa52nalwdaup62o ENTITY{"identifier":"\"","name":[{"value":"\"","locale":"es_ES"}],"external_identifier":"347404090","description":[{"value":"\"","locale":"es_ES"}],"type_lookup":"204"}ONEa5w3mljwesyqjc ENTITY{"identifier":"Radeon Pro 575","name":[{"value":"Radeon Pro 575","locale":"es_ES"}],"external_identifier":"22000560090","description":[{"value":"Radeon Pro 575","locale":"es_ES"}],"type_lookup":"667"}ONEa7ppo5pauwtpa4 ENTITY{"identifier":"GHz","name":[{"value":"GHz","locale":"es_ES"}],"external_identifier":"347546090","description":[{"value":"GHz","locale":"es_ES"}],"type_lookup":"202"}ONEaa3mkeetvctl5k NUMBER516ONEab4pkljq7vlhho ENTITY{"identifier":"GB","name":[{"value":"GB","locale":"es_ES"}],"external_identifier":"347549090","description":[{"value":"GB","locale":"es_ES"}],"type_lookup":"199","glossary":{"term":[{"value":"GB (Gigabyte)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Unidad de medida de capacidad de almacenamiento como, por ejemplo, en una memoria interna, un discos duro o una tarjeta de memoria.","locale":"es_ES"}],"identifier":"11520","name":[{"value":"GB_(GIGABYTE)","locale":"es_ES"}],"external_identifier":"596940054"}}ONEabgd4pscaglu6o NUMBER3.5ONEackff4s43zawxq ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}ONEaehrzaewkxqhfi ENTITY{"identifier":"Gigabit Ethernet","name":[{"value":"Gigabit Ethernet","locale":"es_ES"}],"external_identifier":"366209090","description":[{"value":"Gigabit Ethernet","locale":"es_ES"}],"type_lookup":"185"}ONEaeru2ndkwoh3cg ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}ONEag5bcddr6k5iua NUMBER203ONEagtshfuxpptieo ENTITY{"identifier":"DDR4","name":[{"value":"DDR4","locale":"es_ES"}],"external_identifier":"480263090","description":[{"value":"DDR4","locale":"es_ES"}],"type_lookup":"437"}MANYaiewdct7dyt3my ENTITY{"identifier":"Estéreo","name":[{"value":"Estéreo","locale":"es_ES"}],"external_identifier":"348963090","description":[{"value":"Estéreo","locale":"es_ES"}],"type_lookup":"181"}ONEajzs3pds77jrs6 ENTITY{"identifier":"AMD","name":[{"value":"AMD","locale":"es_ES"}],"external_identifier":"3044204090","description":[{"value":"AMD","locale":"es_ES"}],"type_lookup":"666090"}ONEak7mvbyllv276m NUMBER 2880.0MANYakfne26osto34y ENTITY +{"identifier":"USB 3.0","name":[{"value":"USB 3.0","locale":"es_ES"}],"external_identifier":"349941090","description":[{"value":"USB 3.0","locale":"es_ES"}],"type_lookup":"171","glossary":{"term":[{"value":"USB 3.0","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Es un puerto que sirve para conectar periféricos a un ordenador. Tasa de transferencia de hasta 4.8 Gbps.","locale":"es_ES"}],"identifier":"10323","name":[{"value":"USB_3.0","locale":"es_ES"}],"external_identifier":"596773054"}}{"identifier":"Thunderbolt 3","name":[{"value":"Thunderbolt 3","locale":"es_ES"}],"external_identifier":"11895305090","description":[{"value":"Thunderbolt 3","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"Ranura para tarjetas SDXC","name":[{"value":"Ranura para tarjetas SDXC","locale":"es_ES"}],"external_identifier":"478424090","description":[{"value":"Ranura para tarjetas SDXC","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"Combo de auriculares y micrófono","name":[{"value":"Combo de auriculares y micrófono","locale":"es_ES"}],"external_identifier":"10648839090","description":[{"value":"Combo de auriculares y micrófono","locale":"es_ES"}],"type_lookup":"171"}{"identifier":"Ranura de seguridad Kensington","name":[{"value":"Ranura de seguridad Kensington","locale":"es_ES"}],"external_identifier":"478415090","description":[{"value":"Ranura de seguridad Kensington","locale":"es_ES"}],"type_lookup":"171"}ONEalpw3us43jr6k6 ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}ONEankuorel7ixqjm NUMBER27ONEaorlckj3fy7joa ENTITY {"identifier":"píxeles","name":[{"value":"píxeles","locale":"es_ES"}],"external_identifier":"347402090","description":[{"value":"píxeles","locale":"es_ES"}],"type_lookup":"209","glossary":{"term":[{"value":"Píxel","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Es el nombre con el que se denomina al elemento más pequeño de una imagen digital. La resolución de una imagen o de una pantalla se indica por número de píxeles. Cuanto mayor es el número de píxeles, más alta es la definición.","locale":"es_ES"}],"identifier":"14039","name":[{"value":"PIXEL","locale":"es_ES"}],"external_identifier":"597235054"}}ONEap2o2lyspuaym2 ENTITY{"identifier":"Radeon Pro 575","name":[{"value":"Radeon Pro 575","locale":"es_ES"}],"external_identifier":"19760728090","description":[{"value":"Radeon Pro 575","locale":"es_ES"}],"type_lookup":"598"}MANYaqaggaynxxsnow NUMBER +42111MANYashkcrfkdl56puCOMPLEX[{"locale":"es_ES","value":[{"aqubemlsze7yvo":["Camara FaceTime HD.","Teclado Magic Keyboard incluido. Teclado inalámbrico, ultracompacto y recargable para que te olvides de las pilas.","Ratón Magic mouse incluido."],"a5v2ytqne2eemg":"Más información:"}]}]ONEasvc6ecvr5dnvm NUMBER9.44ONEatv43q5rbyage4 NUMBER4ONEav2t3utnqpnh6g ENTITY{"identifier":"802.11 ac","name":[{"value":"802.11 ac","locale":"es_ES"}],"external_identifier":"22000513090","description":[{"value":"802.11 ac","locale":"es_ES"}],"type_lookup":"144"}ONEavjgyfos7t4lo6 NUMBER 5120.0ONEavmpnzat6h2hie ENTITY{"identifier":"Retina 5K","name":[{"value":"Retina 5K","locale":"es_ES"}],"external_identifier":"19760743090","description":[{"value":"Retina 5K","locale":"es_ES"}],"type_lookup":"599"}ONEavzr66c5qb2jio ENTITY{"identifier":"GB","name":[{"value":"GB","locale":"es_ES"}],"external_identifier":"347549090","description":[{"value":"GB","locale":"es_ES"}],"type_lookup":"199","glossary":{"term":[{"value":"GB (Gigabyte)","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Unidad de medida de capacidad de almacenamiento como, por ejemplo, en una memoria interna, un discos duro o una tarjeta de memoria.","locale":"es_ES"}],"identifier":"11520","name":[{"value":"GB_(GIGABYTE)","locale":"es_ES"}],"external_identifier":"596940054"}}ONEawzwd4lq44lsr4 ENTITY {"identifier":"píxeles","name":[{"value":"píxeles","locale":"es_ES"}],"external_identifier":"347402090","description":[{"value":"píxeles","locale":"es_ES"}],"type_lookup":"209","glossary":{"term":[{"value":"Píxel","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Es el nombre con el que se denomina al elemento más pequeño de una imagen digital. La resolución de una imagen o de una pantalla se indica por número de píxeles. Cuanto mayor es el número de píxeles, más alta es la definición.","locale":"es_ES"}],"identifier":"14039","name":[{"value":"PIXEL","locale":"es_ES"}],"external_identifier":"597235054"}}ONEaxzcsamo3gs3h4 ENTITY{"identifier":"macOS Sierra","name":[{"value":"macOS Sierra","locale":"es_ES"}],"external_identifier":"14916042090","description":[{"value":"macOS Sierra","locale":"es_ES"}],"type_lookup":"175"}ONEaxzsq3mwbdpi52 ENTITY{"identifier":"Uso diario","name":[{"value":"Uso diario","locale":"es_ES"}],"external_identifier":"347082090","description":[{"value":"Uso diario","locale":"es_ES"}],"type_lookup":"592"}MANYayuchmjhgwmmxmCOMPLEX{"alxtskjpxwjlzk":1,"an67k77mgc7z64":{"identifier":"TB","name":[{"value":"TB","locale":"es_ES"}],"external_identifier":"364828090","description":[{"value":"TB","locale":"en_GB"},{"value":"TB","locale":"es_ES"},{"value":"TB","locale":"fr_FR"},{"value":"TB","locale":"pt_PT"}],"type_lookup":"199"}}ONEaz7oi6rgu6myka NUMBER +650.0ONEaz7oqq44v7qfl4 ENTITY{"identifier":"Intel Core i5","name":[{"value":"Intel Core i5","locale":"es_ES"}],"external_identifier":"375394090","description":[{"value":"Intel Core i5","locale":"es_ES"}],"type_lookup":"169"}ONEazbzzcsmi2hij6 ENTITY{"identifier":"Bluetooth 4.2","name":[{"value":"Bluetooth 4.2","locale":"es_ES"}],"external_identifier":"10337921090","description":[{"value":"Bluetooth 4.2","locale":"es_ES"}],"type_lookup":"185"}ONEazdfu4pf2dila4 STRINGx0Ordenadores_Portatil_ISS.SPEC_SECONDARY_TEMPLATE +es_ESVoluminoso348625090Voluminoso +es_ESVoluminoso401$000000000149045292"2019-10-24T11:31Z"2019-11-01T23:00Z"2019-10-31T23:00Z +es_ESCasi a estrenar32681225090Casi a estrenar +es_ESCasi a estrenar2643090$001028515237098 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hde3a14aa-b571-4380-a0bd-f1508d96f999 DELETE<2023-09-02T17:16:12.705257045Z4dataloader-mongo-kafka-job62023-09-02T17:16:19.449711Z(mixer-gtin-agr-kfreeH12a2334a-1e66-43fb-9db2-1e4d4ab40c7a62023-09-02T17:16:25.924380Z,mixer-gtin-calc-pcsflmHbe13a87b-0cbb-419e-a4b9-91f2c5487cab62023-09-02T17:16:26.216192Z,mixer-gtin-calc-pcsflmH86bf5826-c719-47df-ba9c-abde38eebd3162023-09-02T22:36:14.243494Z0mixer-product-calc-kfreeH00b3107b-4448-49d5-8744-7d04f3b66071<2024-01-19T11:18:50.117046542Z$mixer-xsell-mixtriH70f303da-d28c-47bf-80d9-074f6469f31d62024-01-19T11:18:50.582219Z4mixer-packing-units-mixtriHbe05e980-8978-4b12-9ca5-140cecc039ea62024-01-19T11:18:51.012591Z.mixer-offer-badge-mixbiH3f90a580-0200-4a9e-aabd-b75746081d4862024-01-19T11:25:59.493854Z.mixer-offer-badge-mixbiH5c9497be-5a9a-4702-acc9-58432474d271(7×cLoffer(A43303238).publish_ends_extendedIVA02IGIC91 +30687001099443750123001408COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001099440830687050&includeAsWebNovelty +es_ESNovedadDVD"2022-03-20T23:00Z0196147060455 +Rojos +es_ES +Rojos +Rojos +es_ES +RojosGranate +es_ESGranate347656090 +es_ESGranate599599054 +45422 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100630/___45422O1.png +es_ESCOLOR_GRANATE +es_ESColor granateGranate +es_ESGranate0(2022-09-22T07:28:52Z +es_ES(M NK SF WR PL-FLD HD26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000196147060455$000001528016750050TRADICIONAL +es_ESCOLOR_GRANATE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100630/___45422O1.png2401833409301123744056NIKEmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201407/29/1248768132_2_.jpg +es_ESNike +es_ESDeportes997.44463815011 +es_ESDeportes 17.000 +es_ESHCross - Contenedor 2022 Cyber Monday997.44305671011 +es_ESContenedor CMCDN +es_ESChaquetas999.14598528013 +es_ESChaquetas +6.000 +es_ESRopa deportiva999.12473890013 +es_ESRopa deportiva +1.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43303238 +es_ESChaquetas999.14598528013 +es_ESChaquetas +6.000 +es_ESRopa deportiva999.12473890013 +es_ESRopa deportiva +1.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN0238303 +es_ES6NIKE RETAIL SUC. EN ESPAÑA +es_ESnChaqueta de hombre Sportswear Storm-FIT Windrunner Nike +es_ESTrae el frío.Incorporamos la tecnología Storm-FIT y el aislamiento PRIMALOFT® Thermoplume a nuestra chaqueta acolchada Windrunner, elevando su calidez, protección y comodidad en climas fríos. El tejido exterior mate funciona para resguardar la lluvia, mientras que el relleno mantiene el clima controlado, para que puedas salir a las calles cubiertas de nieve con confianza. Mantente abrigado, mantente seco y luce lo mejor posible en los elementos.Ofreciendo una alternativa de plumón sin sacrificar el diseño y la calidez, nuestro relleno PRIMALOFT® Thermoplume presenta una combinación de fibras resistentes al agua que brindan aislamiento, protección contra la intemperie húmeda y compresibilidad. Está hecho con pequeños y sedosos mechones de plumas de fibra.La tecnología Nike Storm-FIT resiste elementos como el viento y el agua para mantenerte cómodo en condiciones climáticas adversas. El relleno aislante PRIMALOFT® funciona para mantenerlo abrigado y seco en condiciones frías y húmedas, para que pueda seguir explorando su ciudad cuando las temperaturas comienzan a bajar.Las líneas de diseño de Chevron están inspiradas en la chaqueta de chándal Windrunner de 1978, que se define por su diseño único y engañosamente simple.A43303238123744056NIKE +es_ESNIKE0998229 +es_ESFNIKE EUROPEAN OPERATION NETHERLANDS998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeDR9605-638 +es_ESnChaqueta de hombre Sportswear Storm-FIT Windrunner Nike +es_ESnChaqueta de hombre Sportswear Storm-FIT Windrunner Nike +es_ESTrae el frío.Incorporamos la tecnología Storm-FIT y el aislamiento PRIMALOFT® Thermoplume a nuestra chaqueta acolchada Windrunner, elevando su calidez, protección y comodidad en climas fríos. El tejido exterior mate funciona para resguardar la lluvia, mientras que el relleno mantiene el clima controlado, para que puedas salir a las calles cubiertas de nieve con confianza. Mantente abrigado, mantente seco y luce lo mejor posible en los elementos.Ofreciendo una alternativa de plumón sin sacrificar el diseño y la calidez, nuestro relleno PRIMALOFT® Thermoplume presenta una combinación de fibras resistentes al agua que brindan aislamiento, protección contra la intemperie húmeda y compresibilidad. Está hecho con pequeños y sedosos mechones de plumas de fibra.La tecnología Nike Storm-FIT resiste elementos como el viento y el agua para mantenerte cómodo en condiciones climáticas adversas. El relleno aislante PRIMALOFT® funciona para mantenerlo abrigado y seco en condiciones frías y húmedas, para que pueda seguir explorando su ciudad cuando las temperaturas comienzan a bajar.Las líneas de diseño de Chevron están inspiradas en la chaqueta de chándal Windrunner de 1978, que se define por su diseño único y engañosamente simple. calificacion1Acalificacion2Acalificacion3M5calificacion4VVcalificacion5ADcalificacion6MO00N479439090M +es_ESME +es_ESEspañol479439090M +es_ESM477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-19T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-20T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-09-19T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Chaquetas","name":[{"value":"Chaquetas","locale":"es_ES"}],"external_identifier":"347705090","description":[{"value":"Chaquetas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Chaquetas","name":[{"value":"Chaquetas","locale":"es_ES"}],"external_identifier":"347862090","description":[{"value":"Chaquetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001528016750050"2022-09-19T22:00Z"2022-09-20T22:00Z"2022-09-19T22:00Z$001099440830687050001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore050Hdbb1f5d3-e9fa-45db-b1c8-0e0ec38c3481 DELETE<2023-09-02T17:23:21.172536326Z4dataloader-mongo-kafka-job62023-09-02T17:23:28.560244Z(mixer-gtin-agr-kfreeHb3334596-bdd9-4cb1-9024-f7e45febadbd62023-09-02T17:24:44.410758Z,mixer-gtin-calc-pcsflmH9c268e6b-4370-4a72-ab44-f46c439fd42c62023-09-02T17:24:46.403593Z,mixer-gtin-calc-pcsflmH0a94b11a-d40c-4655-b341-ba2a80184e9262023-09-03T02:50:49.037534Z0mixer-product-calc-kfreeHeb995c26-5504-4143-b661-085f8caa415e<2024-01-19T11:18:50.597852298Z$mixer-xsell-mixtriH3acca7fd-aedc-4dd3-8557-b627b558935562024-01-19T11:18:50.741752Z4mixer-packing-units-mixtriHe240bff5-f871-4319-9670-6ae5ae0043ca62024-01-19T11:18:51.016040Z.mixer-offer-badge-mixbiH8edcb020-1c48-4535-84bc-5bce34a5ae9f62024-01-19T11:25:59.496267Z.mixer-offer-badge-mixbiH64a8e7b4-594a-4e8b-9c95-2b1b1e8a3765(7×cLoffer(A43278176).publish_ends_extendedIVA02IGIC91 +01210001058443857614001400VALDEMORO +es_ESVALDEMOROCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001058440001210003"2022-03-17T23:00Z8445525917068 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0"2022-09-29T15:31Z +es_ES*VESTIDO ESTAMPADO COM158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008445525917068$000001527941840003TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png24018331657262307390056 +SFERAmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA01/201309/13/1377521437_1_.jpg +es_ES +Sfera +es_ESVestidos999.39090719013 +es_ESVestidos 14.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43278176 +es_ESVestidos999.39090719013 +es_ESVestidos 14.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN7288131600900879 +es_ESVRINDA EXIM INCvCALLE FRIENDS COLONY WEST,15-B-110065 NEW DELHI - (INDIA)  +es_ES6Vestido estampado combinado +es_ESxVestido corto combinado con cuello abotonado. Vuelo en bajo.A432781762307390056 +SFERA +es_ES +SFERA7288131600900879 +es_ES4VRINDA EXIM INC_recargaNFTvCALLE FRIENDS COLONY WEST,15-B-110065 NEW DELHI - (INDIA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +color2662668 +es_ES6Vestido estampado combinado +es_ES6Vestido estampado combinado +es_ESxVestido corto combinado con cuello abotonado. Vuelo en bajo. calificacion1Acalificacion2INcalificacion3RIcalificacion4VVcalificacion5ACcalificacion6I200N47927409038 +es_ES38E +es_ESEspañol479439090M +es_ESM18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02023-01-26T23:00:00.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-09-30T03:48:44.000ZONEate3liesiuooycBOOLEANtrueONEafabpb3cbt6g3oTIMESTAMP02023-01-28T04:22:04.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEabf2vvifj26pzi ENTITY{"identifier":"Corto","name":[{"value":"Corto","locale":"es_ES"}],"external_identifier":"2655626090","description":[{"value":"Corto","locale":"es_ES"}],"type_lookup":"2507"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Vestidos","name":[{"value":"Vestidos","locale":"es_ES"}],"external_identifier":"344732090","description":[{"value":"Vestidos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Viscosa","name":[{"value":"Viscosa","locale":"es_ES"}],"external_identifier":"344748090","description":[{"value":"Viscose","locale":"en_GB"},{"value":"Viscosa","locale":"it_IT"},{"value":"Viscose","locale":"pt_PT"},{"value":"Viscosa","locale":"es_ES"},{"value":"Viscose","locale":"fr_FR"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":100.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022ONEaumavohvmjmvoo ENTITY{"identifier":"CM56","name":[{"value":"CM56","locale":"es_ES"}],"external_identifier":"43937427090","description":[{"value":"Casual","locale":"es_ES"}],"type_lookup":"2667090"}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001527941840003(2022-09-30T03:48:44ZDVD(2023-01-28T04:22:04Z"2023-01-26T23:00Z$001058440001210003001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore003H0340202e-d18d-4126-86b3-76d07b3c6e5e DELETE<2023-09-02T17:47:03.780457726Z4dataloader-mongo-kafka-job62023-09-02T18:05:47.402249Z(mixer-gtin-agr-kfreeHb7351149-329c-47e8-9a21-7ed6a31f9ae662023-09-02T18:05:57.313692Z,mixer-gtin-calc-pcsflmH8ae0b767-15f9-47a3-a817-3e4ab257069a62023-09-02T18:05:58.618161Z,mixer-gtin-calc-pcsflmHc5ebc243-b497-43af-8682-f3abe037594262023-09-03T03:08:03.754351Z0mixer-product-calc-kfreeH3a9ba6e3-68fa-4296-b00b-c0ecb862c07f<2024-01-19T11:18:50.396291009Z$mixer-xsell-mixtriH897a26b2-76d4-46d3-bcdb-d688c554959c62024-01-19T11:18:50.482212Z4mixer-packing-units-mixtriH0bdb4ca3-79db-4523-833f-ee905816428462024-01-19T11:18:51.019596Z.mixer-offer-badge-mixbiH9ffc9a8c-925e-4a61-b629-655c1ed3af0062024-01-19T11:25:59.498359Z.mixer-offer-badge-mixbiH3d37b013-8683-49c2-b1e0-4ef2cbea3214(7×cIVA02IGIC91 +0663000102023-04-25T00:01:19.207Z032442862413001182COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001032418206630040"2022-01-30T23:00Z4065429807292 Grises +es_ES Grises Grises +es_ES GrisesGris +es_ESGris344777090 +es_ESGris5996500544940 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png +es_ESCOLOR_GRIS +es_ESColor GrisGris +es_ESGris0(2022-06-21T15:35:54Z +es_ESAEROREACT LS P +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004065429807292$000001525179240040TRADICIONAL +es_ESCOLOR_GRIS +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png2401826907968123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas +es_ES +Mujer999.17368063013 +es_ES +Mujer +2.000 +es_ESRopa training999.52215013 +es_ESRopa training 20.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESTops999.14621002013 +es_ESTops +1.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A426447695788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_EShTop de mujer Aeroreact Training Light-Support adidas +en_GBA light-support bra for low-impact classes, made in part with recycled materials. +It doesn't matter how you feel when you walk into the studio. What matters is how you feel when you walk out. Push the reset button with this adidas low-impact sports bra. The strappy X-back design flashes some skin. Smooth, breathable fabric and power mesh bring in cool relief. Moisture-absorbing AEROREADY technology makes sure you stay dry and comfortable as you extend, flex and tuck.Tight fit>Pullover design with scoop neckNBreathable fabric feels smooth and cool8Moisture-absorbing AEROREADY +fr_FRUne brassière à maintien léger pour les cours à faible impact, conçue en partie avec des matières recyclées. Peu importe la manière dont tu te sens quand tu arrives au studio. Ce qui compte, c'est ce que tu ressens quand tu en ressors. Appuie sur le bouton reset avec cette brassière de sport adidas adaptée aux entraînements à faible impact. Le dos en X à bretelles laisse apparaître un peu de peau. Sa matière douce et respirante et son power mesh t'offrent un maximum de fraîcheur. La technologie AEROREADY absorbe la transpiration pour te garder confortablement au sec quand tu t'étires, fléchis ou ramènes tes genoux contre ta poitrine.*Coupe près du corps.`Brassière qui s'enfile avec encolure dégagée.LMatière respirante douce et fraîche.`Matière AEROREADY qui absorbe la transpiration.,Dos à bretelles en X. +es_ES.Exigencia y rendimiento No importa cómo te sientas al entrar en el gimnasio. Lo importante son tus sensaciones al salir. Resetea tu rutina con este sujetador deportivo adidas para deportes de bajo impacto. Los tirantes cruzados en la espalda dejan ver tu piel. El tejido suave y transpirable de malla reforzada te ofrece frescura y ventilación. La tecnología transpirable AEROREADY mantiene la piel seca en todo momento.Corte ajustadoFDiseño sin cierre con escote hondoZMaterial transpirable de tacto fresco y suaveDTecnología transpirable AEROREADY>Tirantes cruzados en la espaldaA42644769123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize HM6184 +es_EShTop de mujer Aeroreact Training Light-Support adidas +es_EShTop de mujer Aeroreact Training Light-Support adidas +en_GBA light-support bra for low-impact classes, made in part with recycled materials. +It doesn't matter how you feel when you walk into the studio. What matters is how you feel when you walk out. Push the reset button with this adidas low-impact sports bra. The strappy X-back design flashes some skin. Smooth, breathable fabric and power mesh bring in cool relief. Moisture-absorbing AEROREADY technology makes sure you stay dry and comfortable as you extend, flex and tuck.Tight fit>Pullover design with scoop neckNBreathable fabric feels smooth and cool8Moisture-absorbing AEROREADY +fr_FRUne brassière à maintien léger pour les cours à faible impact, conçue en partie avec des matières recyclées. Peu importe la manière dont tu te sens quand tu arrives au studio. Ce qui compte, c'est ce que tu ressens quand tu en ressors. Appuie sur le bouton reset avec cette brassière de sport adidas adaptée aux entraînements à faible impact. Le dos en X à bretelles laisse apparaître un peu de peau. Sa matière douce et respirante et son power mesh t'offrent un maximum de fraîcheur. La technologie AEROREADY absorbe la transpiration pour te garder confortablement au sec quand tu t'étires, fléchis ou ramènes tes genoux contre ta poitrine.*Coupe près du corps.`Brassière qui s'enfile avec encolure dégagée.LMatière respirante douce et fraîche.`Matière AEROREADY qui absorbe la transpiration.,Dos à bretelles en X. +es_ES.Exigencia y rendimiento No importa cómo te sientas al entrar en el gimnasio. Lo importante son tus sensaciones al salir. Resetea tu rutina con este sujetador deportivo adidas para deportes de bajo impacto. Los tirantes cruzados en la espalda dejan ver tu piel. El tejido suave y transpirable de malla reforzada te ofrece frescura y ventilación. La tecnología transpirable AEROREADY mantiene la piel seca en todo momento.Corte ajustadoFDiseño sin cierre con escote hondoZMaterial transpirable de tacto fresco y suaveDTecnología transpirable AEROREADY>Tirantes cruzados en la espalda +calificacion1Acalificacion2Acalificacion4VVcalificacion5ADcalificacion6MO00N47930109040 +es_ES40E +es_ESEspañol47930109040 +es_ES40 +Talla +Talla479431090C +es_ESCE +es_ESEspañol479431090C +es_ESC +TallaCopapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-06-18T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-06-19T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-06-18T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Tops","name":[{"value":"Tops","locale":"es_ES"}],"external_identifier":"347931090","description":[{"value":"Tops","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Tops","name":[{"value":"Tops","locale":"es_ES"}],"external_identifier":"2859615090","description":[{"value":"Tops","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":89,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster reciclado","name":[{"value":"Poliéster reciclado","locale":"es_ES"}],"external_identifier":"391093090","description":[{"value":"Poliéster reciclado","locale":"es_ES"},{"value":"Poliéster reciclado","locale":"pt_PT"},{"value":"Polyester recyclé","locale":"fr_FR"},{"value":"Recycled polyester","locale":"en_GB"},{"value":"Poliestere riciclato","locale":"it_IT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":11,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastano","locale":"es_ES"},{"value":"Elastano","locale":"pt_PT"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastam","locale":"it_IT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001525179240040"2022-06-18T22:00ZDVD"2022-06-19T22:00Z"2022-06-18T22:00Z$001032418206630040001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore040H2fcf5a7c-9922-49e3-b9d4-3f68f110fa05 DELETE<2023-09-02T17:36:10.054373134Z4dataloader-mongo-kafka-job62023-09-02T17:40:54.130673Z(mixer-gtin-agr-kfreeH92c5a89d-0acf-4052-b379-d5e914673eef62023-09-02T17:52:24.212694Z,mixer-gtin-calc-pcsflmHccf0fb13-1bf0-453a-97f0-19dc0cb8ffbd62023-09-02T17:52:24.311059Z,mixer-gtin-calc-pcsflmHd76a3534-5b64-4473-b773-7f20f3e1c1b362023-09-02T22:34:56.138779Z0mixer-product-calc-kfreeH6854d01d-f095-4a5c-b073-0d5d1d131a9d<2024-01-19T11:18:49.844294048Z$mixer-xsell-mixtriH0277998c-1b5f-4e75-9714-579ae8d8c6ff62024-01-19T11:18:49.938796Z4mixer-packing-units-mixtriHb69447c4-ca1a-4620-9b47-73232d19c01062024-01-19T11:18:50.630918Z.mixer-offer-badge-mixbiHa7738f87-49af-41c4-92b0-fedbc036c7bd62024-01-19T11:25:59.502742Z.mixer-offer-badge-mixbiHb99ab41d-466a-48a4-8355-1d76b03474ff(7×cIVA02IGIC91 +6139200102023-04-24T15:27:05.009Z015336335992001600COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001015360061392012 +es_ESInternet"2058-07-01T22:00Z1229735090Internet +es_ESInternet"2019-07-01T22:00ZDVD"2020-08-05T22:00Z5031592601639Multicolor +es_ESMulticolorMulticolor +es_ESMulticolorMulticolor +es_ESMulticolor352633090 +es_ESMulticolor598507054 +20205 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png +es_ES6COLOR_MULTICOLOR_SECUNDARIO +es_ES6Color Multicolor SecundarioMulticolor +es_ESMulticolor0(2020-08-06T10:14:58Z +es_ES*GINA BACCONI GALILIEA +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005031592601639$000001503377060012TRADICIONAL +es_ES6COLOR_MULTICOLOR_SECUNDARIO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png2401771892555161937056GINA BACCONImarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/97/07/1/00001297071/00001297071197mM1011.jpg +es_ESGina Bacconi  +es_ESVestidos999.8512625013 +es_ESVestidos +1.000 +es_ES2014 Mujer999.2676238013 +es_ES +Mujer +1.000 +es_ESModa999.53895013 +es_ESModaNNN +es_ESRopa997.37865057011 +es_ESRopa +2.000 +es_ESNModa - 20 adicional Moda Mujer Lenceria997.37865055011 +es_ES@20 adicional Moda Mujer LenceriaCDN +es_ES6Contenedor mapeo Limite III997.38170044011 +es_ES6Contenedor mapeo Limite III +4.000 +es_ESNModa - 20 adicional Moda Mujer Lenceria997.37865055011 +es_ES@20 adicional Moda Mujer LenceriaCDN +es_ESVestidos997.2147011 +es_ESVestidos +1.000 +es_ESFiesta Mujer997.2143011 +es_ESFiesta MujerCDN +es_ESVestidos999.39090719013 +es_ESVestidos 14.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ES4Contenedor mapeo Limite II997.38079013011 +es_ES4Contenedor mapeo Limite II +3.000 +es_ESNModa - 20 adicional Moda Mujer Lenceria997.37865055011 +es_ES@20 adicional Moda Mujer LenceriaCDN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A366292130803593 +es_ESvVestido Gina Bacconi con top en tercipopelo y falda bordada +es_ESVestido midi con corpiño de terciopelo forrado. Se recoge y se sujeta con cinturón en la cintura con satén. Falda con malla bordada floral. Cierre con una cremallera oculta en la espalda.A36629213161937056GINA BACCONI +es_ESGINA BACCONI5362251600803593 +es_ESBSHUBETTE OF LONDON LTD_recargaNFTtCALLE LG 2 APSLEY WAY,..- LONDON NW2 7HF - (REINO UNIDO) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeSTT2538_MU +es_ESvVestido Gina Bacconi con top en tercipopelo y falda bordada +es_ESvVestido Gina Bacconi con top en tercipopelo y falda bordada +es_ESVestido midi con corpiño de terciopelo forrado. Se recoge y se sujeta con cinturón en la cintura con satén. Falda con malla bordada floral. Cierre con una cremallera oculta en la espalda. +calificacion1W9calificacion2Acalificacion3ROcalificacion4VVcalificacion5B0047931509042 +es_ES42E +es_ESEspañol47910909012 +es_ES1218171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoq ONEa2wkf4iqk324hsBOOLEAN +falseONEa2ynyjkfoo2woqTIMESTAMP02098-12-31T23:00:01.000ZONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02018-12-31T23:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02021-03-29T22:00:01.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02020-08-12T22:00:00.000ZMANYaqundqcyqbyf5mTIMESTAMP02019-07-01T22:00:00.000ZMANYasrguixcdyik32TIMESTAMP02058-07-01T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}Fechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"No lavar","name":[{"value":"No lavar","locale":"es_ES"}],"external_identifier":"484893090","description":[{"value":"No lavar","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar blanqueante","name":[{"value":"No usar blanqueante","locale":"es_ES"}],"external_identifier":"484894090","description":[{"value":"No usar blanqueante","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Planchar del revés","name":[{"value":"Planchar del revés","locale":"es_ES"}],"external_identifier":"484899090","description":[{"value":"Planchar del revés","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"Limpieza en seco","name":[{"value":"Limpieza en seco","locale":"es_ES"}],"external_identifier":"349528090","description":[{"value":"Limpieza en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Limpieza en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201612/07/35144_2_.png","size":"small"}],"description":[{"value":"Limpieza en seco","locale":"es_ES"}],"identifier":"35144","name":[{"value":"LIMPIEZA_EN_SECO","locale":"es_ES"}],"external_identifier":"599216054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Flores","name":[{"value":"Flores","locale":"es_ES"}],"external_identifier":"9338924090","description":[{"value":"Flores","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Pico","name":[{"value":"Pico","locale":"es_ES"}],"external_identifier":"485160090","description":[{"value":"Pico","locale":"es_ES"}],"type_lookup":"1595"}ONEabf2vvifj26pzi ENTITY{"identifier":"Midi","name":[{"value":"Midi","locale":"es_ES"}],"external_identifier":"9612160090","description":[{"value":"Midi","locale":"es_ES"}],"type_lookup":"2507"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Sin mangas","name":[{"value":"Sin mangas","locale":"es_ES"}],"external_identifier":"485204090","description":[{"value":"Sin mangas","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Vestidos","name":[{"value":"Vestidos","locale":"es_ES"}],"external_identifier":"344732090","description":[{"value":"Vestidos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliéster","locale":"es_ES"},{"value":"Poliéster","locale":"pt_PT"},{"value":"Polyester","locale":"fr_FR"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliestere","locale":"it_IT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2019Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001503377060012"2020-08-12T22:00ZDVD(2021-03-29T22:00:01Z(2018-12-31T23:00:01Z$001015360061392012001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore012Hc2f03f7a-8162-4401-9328-0dc85d91965e DELETE<2023-09-02T17:34:37.533741574Z4dataloader-mongo-kafka-job62023-09-02T17:43:37.466390Z(mixer-gtin-agr-kfreeH82c33c45-4e05-487b-9230-41d5ef081f6462023-09-02T17:47:34.633198Z,mixer-gtin-calc-pcsflmHb2586845-9eec-477d-bff9-5aabd54d3df462023-09-02T17:47:34.719844Z,mixer-gtin-calc-pcsflmHc3c098b1-048b-4f01-8a45-231fa4963f1562023-09-02T22:43:36.454528Z0mixer-product-calc-kfreeH6fd22baf-8ead-4dca-b4bb-43e54737b2e7<2024-01-19T11:18:49.805561271Z$mixer-xsell-mixtriH16dbfa68-f311-4d68-b36a-9180efecbfba62024-01-19T11:18:49.951667Z4mixer-packing-units-mixtriH8b8f487f-3965-4a2b-95ea-8752970e091162024-01-19T11:18:50.633056Z.mixer-offer-badge-mixbiHe8c13aed-c5f2-4def-b1e5-91356caf26c362024-01-19T11:25:59.504243Z.mixer-offer-badge-mixbiHb61241d4-e11b-4bf8-a920-75d86c07f153(7×c,7ǻmf!IVA02IGIC91 +3131100102023-04-24T15:19:37.044Z010437496236001403COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001010440331311038"2020-11-10T23:00Z4064047927368 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2020-12-01T10:11:38Z +es_ES*SR LUX HR 2.0 AOP TIG +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004064047927368$000001507086870038TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401781015807171002056 REEBOKmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201411/17/1249289576_1_.jpg +es_ES Reebok + +es_ES Mallas999.14619982013 +es_ES Mallas +3.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES&Pantalones y Mallas999.53674013 +es_ES&Pantalones y Mallas 18.000 +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ES0Ropa para yoga y pilates999.37734565013 +es_ES0Ropa para yoga y pilates +2.000 +es_ESYoga y pilates999.37734563013 +es_ESYoga y pilates 26.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ES +Mujer999.17368063013 +es_ES +Mujer +2.000 +es_ESRopa training999.52215013 +es_ESRopa training 20.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A380050885788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ESPMallas de mujer SR Lux HR 2.0 AOP Reebok +en_GBIf there's one garment that can't be missed in your training styles, it's leggings. Opt for models in colour that stand out for their design personality and the quality of their fabric, like this hard-wearing Reebok model, and leave serious and boring garments to one side. +fr_FRS'il y a un élément qui ne peut pas manquer dans vos styles d'entraînement, c'est bien les jambières. Optez pour des modèles en couleur qui se distinguent par leur personnalité et la qualité de leur tissu, comme ce modèle résistant de Reebok, et laissez de côté les vêtements sérieux et ennuyeux. +es_ESSi hay una prenda que no puede faltar en tus estilismos de entrenamiento, esos son los leggings. Apuesta por modelos en color que destaquen por la personalidad de su diseño y la calidad de su tejido, como este resistente modelo de Reebok y deja a un lado las prendas serias y aburridas.A38005088171002056 REEBOK +es_ES REEBOK5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize GI8036 +es_ESPMallas de mujer SR Lux HR 2.0 AOP Reebok +es_ESPMallas de mujer SR Lux HR 2.0 AOP Reebok +en_GBIf there's one garment that can't be missed in your training styles, it's leggings. Opt for models in colour that stand out for their design personality and the quality of their fabric, like this hard-wearing Reebok model, and leave serious and boring garments to one side. +fr_FRS'il y a un élément qui ne peut pas manquer dans vos styles d'entraînement, c'est bien les jambières. Optez pour des modèles en couleur qui se distinguent par leur personnalité et la qualité de leur tissu, comme ce modèle résistant de Reebok, et laissez de côté les vêtements sérieux et ennuyeux. +es_ESSi hay una prenda que no puede faltar en tus estilismos de entrenamiento, esos son los leggings. Apuesta por modelos en color que destaquen por la personalidad de su diseño y la calidad de su tejido, como este resistente modelo de Reebok y deja a un lado las prendas serias y aburridas. calificacion1A7calificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO06479443090S +es_ESSE +es_ESEspañol479443090S +es_ESS477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-07-19T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-08-06T03:31:43.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02020-11-28T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Mallas","name":[{"value":"Mallas","locale":"es_ES"}],"external_identifier":"351473090","description":[{"value":"Mallas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Mallas","name":[{"value":"Mallas","locale":"es_ES"}],"external_identifier":"485317090","description":[{"value":"Mallas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster reciclado","name":[{"value":"Poliéster reciclado","locale":"es_ES"}],"external_identifier":"391093090","description":[{"value":"Poliéster reciclado","locale":"es_ES"},{"value":"Poliéster reciclado","locale":"pt_PT"},{"value":"Polyester recyclé","locale":"fr_FR"},{"value":"Recycled polyester","locale":"en_GB"},{"value":"Poliestere riciclato","locale":"it_IT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":85},{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastano","locale":"es_ES"},{"value":"Elastano","locale":"pt_PT"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastam","locale":"it_IT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":15}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001507086870038"2020-11-28T23:00ZDVD(2021-08-06T03:31:43Z"2021-07-19T22:00Z$001010440331311038001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore038Hfa0aba45-14fa-4424-9224-d31d25a99db3 DELETE<2023-09-02T17:34:11.203337933Z4dataloader-mongo-kafka-job62023-09-02T17:39:33.077475Z(mixer-gtin-agr-kfreeH765296af-af1d-4d9f-9ccc-52c93a357a1962023-09-02T17:52:31.908381Z,mixer-gtin-calc-pcsflmHb0684b6d-d6c4-4055-97fb-d2a8fb5dcc9462023-09-02T17:52:41.412751Z,mixer-gtin-calc-pcsflmHedb00b34-706c-400b-9095-683f6098522762023-09-02T22:35:39.136982Z0mixer-product-calc-kfreeHec07a9a8-b4a3-4daa-8d75-0481a596de1a<2024-01-19T11:18:50.011291931Z$mixer-xsell-mixtriHac1f5842-80f1-4bd0-82be-7e1c2f07042162024-01-19T11:18:50.080036Z4mixer-packing-units-mixtriH9669c9b8-8fae-42e8-8838-0c57b3a2548a62024-01-19T11:18:50.708002Z.mixer-offer-badge-mixbiHdb20bccd-cee5-4bd8-83d8-7faf6fe292d862024-01-19T11:25:59.506469Z.mixer-offer-badge-mixbiHe14acce9-03d9-49a4-ba5e-0d8829553837(7×cIVA08IGIC90 +3947100102023-03-21T03:19:29.726Z0065985148001123COMPRA EN FIRME +es_ESCOMPRA EN FIRME*LECTURAS RECOMENDADAS +es_ES*LECTURAS RECOMENDADASSTERLING +es_ESSTERLING$001006512339471 "2018-02-07T23:00Z97884939297320(2013-04-17T02:39:17Z +es_ES LIBROS +es_ES Libros274977090 Libros395ML +es_ESml +0.0009788493929732$0000000001007031892401471399989357605056AUTOR EDITOR +es_ESAUTOR-EDITOR +es_ES8Guías turísticas - ESPAÑA999.6866346013 +es_ES8Guías turísticas - ESPAÑA +9.000 +es_ES Viajes y turismo999.6866333013 +es_ES Viajes y turismo 49.000 +es_ES Libros999.54302013 +es_ES LibrosNNN +es_ES Libros274977090 Libros395A90090935634211602078865 +es_ESAUTOR-EDITOR ,- - ()  +es_ES8Historia de la costa del solA9009093357605056AUTOR-EDITOR +es_ESAUTOR-EDITOR5053401600246553 +es_ES>DISTRIBUCIONES CAL MALAGA, S.L.CALLE CL BODEGUEROS,43 NAVE 3,..-29006 MALAGA - MALAGA (ESPAñA) 998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de Productos9788493929732 +es_ES8Historia de la costa del sol +es_ES8Historia de la costa del sol +calificacion1Acalificacion2Acalificacion3E5calificacion4VVcalificacion5AC00pler4twpwa2rdqpkcwmvhkxxd52gpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02013-04-17T02:25:48.000ZONEafabpb3cbt6g3oTIMESTAMP02016-03-28T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02013-04-15T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa3aauuktnvama2 ENTITY{"identifier":"3043919","name":[{"value":"JUAN DE DIOS MELLADO","locale":"es_ES"}],"external_identifier":"565611051","given_name":"JUAN DE DIOS","family_name":"MELLADO","birth_place":[],"death_place":[],"biography":[],"media_objects":[],"normalized_name":"juan-de-dios-mellado"}ONEa3novp2ls57ixm STRINGv[{"locale":"es_ES","value":"GUíAS TURíSTICAS - ESPAÑA"}]ONEa5ej6iwjweshes STRING000ONEacnblp3uq557wk STRING001ONEadizbj7oydkivk STRING*JUAN DE DIOS_MELLADO_ONEadwyeen33wnwra STRING005ONEangal4rqdmxpse STRING^[{"locale":"es_ES","value":"TURISMO Y VIAJES"}]ONEaogwgan32v4m66 STRINGAGMANYaoyr2i73cpmiu6 ENTITY{"identifier":"Castellano","name":[{"value":"Castellano","locale":"es_ES"}],"external_identifier":"347423090","description":[{"value":"Castellano","locale":"es_ES"}],"type_lookup":"157"}ONEau4wikbtn4ylzk STRING8Historia de la costa del solMANY*libros_iss_calculatedCOMPLEX{"name":"JUAN DE DIOS MELLADO","rol":"Autor","grouper":"author","normalize_name_grouper":"author|juan-de-dios-mellado"}Libros_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000100703189"2013-04-15T22:00Z"2016-03-28T22:00Z(2013-04-17T02:25:48Z$001006512339471 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H0cda4843-53fd-4ae7-8f53-f30ed641b51e DELETE<2023-09-02T17:24:35.646145538Z4dataloader-mongo-kafka-job62023-09-02T17:24:47.598842Z(mixer-gtin-agr-kfreeHee47b333-f966-433d-a88b-83d204e5f0f762023-09-02T17:26:17.802763Z,mixer-gtin-calc-pcsflmH0d1f388c-7b61-4e74-955a-6c8ae89ce4c462023-09-02T17:26:19.304034Z,mixer-gtin-calc-pcsflmHc2be7480-804e-4f47-ab4e-212f5504cb0762023-09-03T02:41:58.980345Z0mixer-product-calc-kfreeHcd34a568-80b2-44eb-888e-729ce99b7449<2024-01-19T11:18:38.526328039Z$mixer-xsell-mixtriHda218df7-3f11-4b94-a515-0ba896367a0a62024-01-19T11:18:38.739570Z4mixer-packing-units-mixtriHf6baadcc-fd82-4cd7-bc70-92316857c19762024-01-19T11:18:51.023193Z.mixer-offer-badge-mixbiH7b094af8-e21f-48a2-ad06-3265313c8cf962024-01-19T11:25:59.508757Z.mixer-offer-badge-mixbiH82757f0e-d737-4915-8ff8-37699d73f5c9(7×cLoffer(A38785193).publish_ends_extendedIVA02IGIC91 +08999001003339356290001857COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001003385708999046&includeAsWebNovelty +es_ESNovedadDVD +es_ESProducto sostenible compuesto de materiales reciclados y/o regenerados a partir de subproductos procedentes de la misma actividad o de otra actividad diferenciada, incluyendo los bioplásticos y biopolímeros31820068090 +es_ESProducto sostenible compuesto de materiales reciclados y/o regenerados a partir de subproductos procedentes de la misma actividad o de otra actividad diferenciada, incluyendo los bioplásticos y biopolímeros31845111054 +32205 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32205_1_.png +es_ES6OTROS_MATERIALES_RECICLADOS +es_ES6Otros materiales reciclados +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32205_1_.png018 +es_ES6Otros materiales reciclados:SUSTAINABILITY_CLOSING_CIRCLE"2021-02-03T23:00Z8720115145473 Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2021-06-18T15:02:37Z +es_ES&DEPORTIVO ESSENTIAL155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008720115145473$000001509813620046TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401788201326123709056TOMMY HILFIGERmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/0/00001269350/00001269350354mM1011.jpg +es_ESTommy Hilfiger +es_ESVAC canje997.37430941011 +es_ESVAC canje +9.000 +es_ES2Moda_Zapatos_Informativas997.33067667011 +es_ES2Moda_Zapatos_InformativasCDN +es_ESZapatillas999.39073065013 +es_ESZapatillas +3.000 +es_ESZapatos999.39072678013 +es_ESZapatos +2.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ES8Zapatillas deportivas casual997.32835412011 +es_ES8Zapatillas deportivas casualCD +es_ES Hombre997.32835414011 +es_ES Hombre +2.000 +es_ES8Zapatillas deportivas casual997.32835412011 +es_ES8Zapatillas deportivas casualCDN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A38785193 +es_ESZapatillas999.39073065013 +es_ESZapatillas +3.000 +es_ESZapatos999.39072678013 +es_ESZapatos +2.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN4890791600068585 +es_ES0TOMMY HILFIGER EUROPE BVCALLE CR LAUREA MIRO,403-08980 ST. FELIU DE LLOBREGAT - BARCELONA (ESPAñA)  +es_ESZapatillas de hombre de piel Tommy Hilfiger en azul marino con logo bandera +es_ESZapatillas casco de piel en color azul marino. Logo bandera pequeña Tommy Hilfiger en el lateral y talón. Detalles de colores corporativos en la lengüeta y talonera. Interior y plantilla de poliéster reciclado. Cierre con cordones.A38785193123709056TOMMY HILFIGER +es_ESTOMMY HILFIGER4890791600068585 +es_ES0TOMMY HILFIGER EUROPE BVCALLE CR LAUREA MIRO,403-08980 ST. FELIU DE LLOBREGAT - BARCELONA (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeFM0FM03739DW5 +es_ESZapatillas de hombre de piel Tommy Hilfiger en azul marino con logo banderaFM0FM03739DW5 +es_ESZapatillas de hombre de piel Tommy Hilfiger en azul marino con logo bandera +es_ESZapatillas casco de piel en color azul marino. Logo bandera pequeña Tommy Hilfiger en el lateral y talón. Detalles de colores corporativos en la lengüeta y talonera. Interior y plantilla de poliéster reciclado. Cierre con cordones. calificacion1Acalificacion2Acalificacion3RRcalificacion4VVcalificacion5NScalificacion6CA0047933909046 +es_ES46E +es_ESEspañol47933909046 +es_ES46477062090Español +Tallapler4twpwa2rdqpwe2kceprh5w3aphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRING.Publicar calif agotadorONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-16T05:09:10.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-17T05:09:10.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-08-04T04:43:53.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE,MANYa3mfirlezq5meo NUMBER +100.0ONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa6t5qpj7cwnmaw NUMBER80.020.0MANYa7jpc7s7go77wi ENTITY{"identifier":"Otros materiales","name":[{"value":"Otros materiales","locale":"es_ES"}],"external_identifier":"349472090","description":[{"value":"Otros materiales","locale":"es_ES"}],"type_lookup":"1633"}ONEa7xqyqnqtfqof6 ENTITY{"identifier":"Zapatillas de piel","name":[{"value":"Zapatillas de piel","locale":"es_ES"}],"external_identifier":"3020335090","description":[{"value":"Zapatillas de piel","locale":"es_ES"}],"type_lookup":"1620"}MANYaao3an6xqyn27u ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}MANYafrdyt4ml6523m ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Goma","name":[{"value":"Goma","locale":"es_ES"}],"external_identifier":"477871090","description":[{"value":"Goma","locale":"es_ES"}],"type_lookup":"1633"}ONEalnwwhqri3drmq ENTITY{"identifier":"Cordones","name":[{"value":"Cordones","locale":"es_ES"}],"external_identifier":"386376090","description":[{"value":"Cordones","locale":"es_ES"}],"type_lookup":"1574"}MANYamf7ns2ejiozuc NUMBER +100.0MANYamzex7cmn57eei ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Piel","name":[{"value":"Piel","locale":"es_ES"}],"external_identifier":"347595090","description":[{"value":"Piel","locale":"es_ES"}],"type_lookup":"1633"}{"identifier":"Poliuretano","name":[{"value":"Poliuretano","locale":"es_ES"}],"external_identifier":"347848090","description":[{"value":"Poliuretano","locale":"es_ES"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEauik4rxccjjcze ENTITY{"identifier":"Redonda","name":[{"value":"Redonda","locale":"es_ES"}],"external_identifier":"3020307090","description":[{"value":"Redonda","locale":"es_ES"}],"type_lookup":"1612"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Zapatillas","name":[{"value":"Zapatillas","locale":"es_ES"}],"external_identifier":"349403090","description":[{"value":"Zapatillas","locale":"es_ES"}],"type_lookup":"1620"}{"identifier":"Casual","name":[{"value":"Casual","locale":"es_ES"}],"external_identifier":"373606090","description":[{"value":"Casual","locale":"es_ES"}],"type_lookup":"1620"}MANYauqqk66n7fk6uu ENTITY{"identifier":"Piel","name":[{"value":"Piel","locale":"es_ES"}],"external_identifier":"347595090","description":[{"value":"Piel","locale":"es_ES"}],"type_lookup":"1633"}ONEauur46vhpycka4 ENTITY{"identifier":"Zapatos hombre","name":[{"value":"Zapatos hombre","locale":"es_ES"}],"external_identifier":"347770090","description":[{"value":"Zapatos hombre","locale":"es_ES"}],"type_lookup":"1611"}MANYaxhbfopxaa6ppy ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}MANYaxr5m2ljibnmui NUMBER2021MANYaysizsllntmwzgCOMPLEX{"ahx7en5mskblj4":{"identifier":"Forro","name":[{"value":"Forro","locale":"es_ES"}],"external_identifier":"477728090","description":[{"value":"Lining","locale":"en_GB"},{"value":"Forro","locale":"es_ES"},{"value":"Doublure","locale":"fr_FR"},{"value":"Forro","locale":"pt_PT"}],"type_lookup":"1576"},"abjlulhwauqmm2":[{"abywf4lkkpef2w":100.0,"a22ina6zdhutbm":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"aed5i4gt3gvp5u":{"identifier":"Otros materiales","name":[{"value":"Otros materiales","locale":"es_ES"}],"external_identifier":"349472090","description":[{"value":"Altri materiali","locale":"it_IT"},{"value":"Other materials","locale":"en_GB"},{"value":"Otros materiales","locale":"es_ES"},{"value":"Autres matériaux","locale":"fr_FR"},{"value":"Outros materiais","locale":"pt_PT"}],"type_lookup":"1633"}}]}{"ahx7en5mskblj4":{"identifier":"Plantilla","name":[{"value":"Plantilla","locale":"es_ES"}],"external_identifier":"10765251090","description":[{"value":"Insole","locale":"en_GB"},{"value":"Plantilla","locale":"es_ES"},{"value":"Semelle intérieure","locale":"fr_FR"},{"value":"Palmilha","locale":"pt_PT"}],"type_lookup":"1576"},"abjlulhwauqmm2":[{"abywf4lkkpef2w":52,"a22ina6zdhutbm":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"aed5i4gt3gvp5u":{"identifier":"Otros materiales","name":[{"value":"Otros materiales","locale":"es_ES"}],"external_identifier":"349472090","description":[{"value":"Altri materiali","locale":"it_IT"},{"value":"Other materials","locale":"en_GB"},{"value":"Otros materiales","locale":"es_ES"},{"value":"Autres matériaux","locale":"fr_FR"},{"value":"Outros materiais","locale":"pt_PT"}],"type_lookup":"1633"}}]}Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001509813620046(2021-08-04T04:43:53Z(2022-09-17T05:09:10Z(2022-09-16T05:09:10Z$001003385708999046001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore046Ha69465a1-6929-4783-b169-d2b3609a854c DELETE<2023-09-02T17:24:11.514026180Z4dataloader-mongo-kafka-job62023-09-02T17:24:21.846007Z(mixer-gtin-agr-kfreeH11deb96c-323d-4768-b051-b9809a88623862023-09-02T17:24:43.613952Z,mixer-gtin-calc-pcsflmH7e4f646c-adb4-4777-bbe7-18a79684cb4f62023-09-02T17:24:44.417723Z,mixer-gtin-calc-pcsflmHe5afe965-a92a-427a-a3d8-5de0d677f1c662023-09-03T02:50:54.384964Z0mixer-product-calc-kfreeHc12ec241-ea9e-4a87-8e4d-68a80bdd15fb<2024-01-19T11:18:50.625081484Z$mixer-xsell-mixtriH835610b9-364a-4965-84bd-1a15c49bbe7f62024-01-19T11:18:50.744273Z4mixer-packing-units-mixtriHc7fd4baf-2d36-4d31-bd6a-df43bc31180d62024-01-19T11:18:51.136363Z.mixer-offer-badge-mixbiH8204a5bd-952b-4dca-9d4c-a1b250573e6662024-01-19T11:25:59.511928Z.mixer-offer-badge-mixbiH13dad1b2-a5d4-4aad-b7d6-1bc565cbc96e(7×cLoffer(A32513334).publish_ends_extendedIVA02IGIC91 +00409001011034655285001417COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001011041700409090&includeAsWebNovelty +es_ESNovedadDVD"2019-10-02T22:00Z8431410692073Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2020-03-24T13:06:58Z +es_ESBODY RELLENO158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008431410692073$000001491166320090TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png2401741036248375536056PROMISE +es_ESPromise +es_ES4Corpiños y bodys de novia999.39091584013 +es_ES4Corpiños y bodys de novia +4.000 +es_ES&Lencería de novias999.39091580013 +es_ES&Lencería de novias 30.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ES +Bodys999.39072768013 +es_ES +Bodys 17.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNt8431410691601843141069166384314106915958431410691618843141069162584314106916708431410691632843141069164984314106916568431410691410843141069153384314106914588431410691502843141069143484314106914418431410691519843141069152684314106915408431410691427843141069147284314106914038431410691465843141069149684314106914898431410691335843141069132884314106913598431410691298843141069126784314106913808431410691342843141069131184314106913048431410691366843141069137384314106912818431410691274843141069139784314106912508431410694985843141069492384314106950368431410694930843141069490984314106949168431410694879843141069488684314106948938431410694992843141069494784314106950058431410695029843141069496184314106949782401742166067843141069501284314106950438431410694954A32513482A32513442A32513623A32632986158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A32513334 +es_ES4Corpiños y bodys de novia999.39091584013 +es_ES4Corpiños y bodys de novia +4.000 +es_ES&Lencería de novias999.39091580013 +es_ES&Lencería de novias 30.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN5085771600288340 +es_ESSEA LIKE, SLCALLE SANT GALDERIC,,21-08395 SANT POL DE MAR - BARCELONA (ESPAñA)  +es_ES:Body Bridal con foam y encaje +es_ESBody con aro, foam, espalda escotada y detalles delanteros de encaje.A32513334375536056PROMISE +es_ESPROMISE5085771600288340 +es_ESSEA LIKE, SLCALLE SANT GALDERIC,,21-08395 SANT POL DE MAR - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize +B0656 +es_ES:Body Bridal con foam y encaje +es_ES:Body Bridal con foam y encaje +es_ESBody con aro, foam, espalda escotada y detalles delanteros de encaje. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AH0047942309090 +es_ES90E +es_ESEspañol47942309090 +es_ES90477062090Español +Talla479429090B +es_ESBE +es_ESEspañol479429090B +es_ESB477062090EspañolCopapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-05T00:40:20.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-06T00:40:20.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02020-03-24T23:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}{"identifier":"No centrifugar","name":[{"value":"No centrifugar","locale":"es_ES"}],"external_identifier":"347781090","description":[{"value":"No centrifugar","locale":"es_ES"}],"type_lookup":"1584"}MANYa4ljbqm5nabztw ENTITY{"identifier":"Continuidad","name":[{"value":"Continuidad","locale":"es_ES"}],"external_identifier":"2696215090","description":[{"value":"Continuidad","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Tirantes","name":[{"value":"Tirantes","locale":"es_ES"}],"external_identifier":"485212090","description":[{"value":"Tirantes","locale":"es_ES"}],"type_lookup":"1597"}MANYagio3trrjaqhgg ENTITY{"identifier":"Fibras sintéticas","name":[{"value":"Fibras sintéticas","locale":"es_ES"}],"external_identifier":"22937672090","description":[{"value":"Fibras sintéticas","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Bodys","name":[{"value":"Bodys","locale":"es_ES"}],"external_identifier":"2700637090","description":[{"value":"Bodys","locale":"es_ES"}],"type_lookup":"1599"}ONEaj74fe6v7bf7eg ENTITY{"identifier":"No","name":[{"value":"No","locale":"es_ES"}],"external_identifier":"347406090","description":[{"value":"No","locale":"es_ES"}],"type_lookup":"144"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":81,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}},{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"adbyfb4jfvuv5k":19,"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001491166320090"2020-03-24T23:00Z(2022-10-06T00:40:20Z(2022-10-05T00:40:20Z$001011041700409090001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore090Hc7142379-37c7-407a-aa48-fdf40f747c7e DELETE<2023-09-02T17:30:31.203539184Z4dataloader-mongo-kafka-job62023-09-02T17:31:20.246235Z(mixer-gtin-agr-kfreeH6290c9c6-476f-4478-a3d9-013f65da5dac62023-09-02T17:39:50.508466Z,mixer-gtin-calc-pcsflmH5ea3a58e-89d2-46f8-8c4c-576b3a85658362023-09-02T17:39:53.909092Z,mixer-gtin-calc-pcsflmH2ed82d05-80ce-4f97-a4ab-0372331fad3162023-09-03T03:03:45.892867Z0mixer-product-calc-kfreeHd7f58509-9f6c-4368-a3eb-05e5f36e4151<2024-01-19T11:18:39.773649073Z$mixer-xsell-mixtriH4b57e289-3cbf-44d0-a50b-39defb38161462024-01-19T11:18:39.923339Z4mixer-packing-units-mixtriH9114a832-65d1-4b78-aa81-591b5d14367d62024-01-19T11:18:51.314700Z.mixer-offer-badge-mixbiH4942cbc1-88fb-4d22-8ab4-ce97aa05181262024-01-19T11:25:59.513243Z.mixer-offer-badge-mixbiH5e62443f-dac0-451e-af45-1c0de470d2df(7×cLoffer(A42589571).publish_ends_extendedIVA02IGIC91 +12664001029341494622001400COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001029340012664005&includeAsWebNovelty +es_ESNovedadDVD +es_ESFibra natural en la que no se ha utilizado insumos externos que no sean ecológicos.31820044090 +es_ESFibra natural en la que no se ha utilizado insumos externos que no sean ecológicos.31845076054 +13230 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/13230_1_.png +es_ES,FIBRA_NATURAL_ORGANICA +es_ES.Fibra natural orgánica +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/13230_1_.png033 +es_ES.Fibra natural orgánica*SUSTAINABILITY_ORIGIN"2022-01-25T23:00Z5057847821645 +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa claro +es_ESRosa claro114324090 +es_ES Color Rosa claro19941805054 +35608 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201706/16/35608_1_.png +es_ES COLOR_ROSA_CLARO +es_ES Color Rosa claroRosa claro +es_ESRosa claro0(2022-02-01T17:24:36Z +es_ESCAMISETAS158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005057847821645$000001524969560005TRADICIONAL +es_ES COLOR_ROSA_CLARO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201706/16/35608_1_.png24018263717833160085056SUPERDRY +es_ESSuperdry +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESRopa997.38159713011 +es_ESRopa +2.000 +es_ESModa Mujer997.38150773011 +es_ESModa Mujer +5.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42589571 +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0903616 +es_ESVBO GRANT THORNTON EFFICIENTIA DKH RETAILLTD +es_ESCamiseta de algodón orgánico con cuello de pico y bolsillo Studios. +es_ESUna prenda clásica, cómoda y versátil. Tanto si llevas esta camiseta sola como debajo de una chaqueta, consigue tu mejor look con ella esta temporada. Corte relajado: el corte clásico de Superdry. Ni muy estrecho, ni muy holgado, simplemente perfecto. Elige tu talla habitual. Cuello de pico. Manga corta. Bolsillo en el lado derecho del pecho. Algodón orgánico. Logotipo bordado. Etiqueta con el logotipo de Superdry. Confeccionada en una mezcla de algodón orgánico y TENCEL™. El algodón orgánico se cultiva con pesticidas y fertilizantes naturales, en lugar de químicos. Estas prácticas mejoran la salud del suelo, logrando reducir el uso del agua en hasta un 80 %, lo que contribuye a la mejora de las condiciones de nuestro planeta y de los agricultores que lo cultivan. Las fibras modales TENCEL™ están fabricadas con tecnología Eco Soft, una elección respetuosa con el medioambiente.A425895713160085056SUPERDRY +es_ESSUPERDRY10593731600903616 +es_ESVBO GRANT THORNTON EFFICIENTIA DKH RETAILLTD`CALLE RUE SIMONIS,53-1050 BRUSSELS - (BELGICA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeW1010521B +es_ESCamiseta de algodón orgánico con cuello de pico y bolsillo Studios. +es_ESCamiseta de algodón orgánico con cuello de pico y bolsillo Studios. +es_ESUna prenda clásica, cómoda y versátil. Tanto si llevas esta camiseta sola como debajo de una chaqueta, consigue tu mejor look con ella esta temporada. Corte relajado: el corte clásico de Superdry. Ni muy estrecho, ni muy holgado, simplemente perfecto. Elige tu talla habitual. Cuello de pico. Manga corta. Bolsillo en el lado derecho del pecho. Algodón orgánico. Logotipo bordado. Etiqueta con el logotipo de Superdry. Confeccionada en una mezcla de algodón orgánico y TENCEL™. El algodón orgánico se cultiva con pesticidas y fertilizantes naturales, en lugar de químicos. Estas prácticas mejoran la salud del suelo, logrando reducir el uso del agua en hasta un 80 %, lo que contribuye a la mejora de las condiciones de nuestro planeta y de los agricultores que lo cultivan. Las fibras modales TENCEL™ están fabricadas con tecnología Eco Soft, una elección respetuosa con el medioambiente. calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5Bcalificacion612PDN47931509042 +es_ES42E +es_ESEspañol47914809016 +es_ES1618171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-22T03:58:36.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-04-27T04:15:32.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar máximo 30º C","name":[{"value":"Lavar máximo 30º C","locale":"es_ES"}],"external_identifier":"21449008090","description":[{"value":"Lavar máximo 30º C","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}{"identifier":"Planchado max 100º","name":[{"value":"Planchado max 100º","locale":"es_ES"}],"external_identifier":"347899090","description":[{"value":"Planchado max 100º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","name":[{"value":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","locale":"es_ES"}],"external_identifier":"10460407090","description":[{"value":"Se recomienda leer detenidamente los consejos de lavado en las etiquetas de la prenda","locale":"es_ES"}],"type_lookup":"1584"} +{"identifier":"Secadora a baja temperatura","name":[{"value":"Secadora a baja temperatura","locale":"es_ES"}],"external_identifier":"372933090","description":[{"value":"Secadora a baja temperatura","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Secadora a baja temperatura","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___54947O1.png","size":"small"}],"description":[{"value":"Secadora a baja temperatura","locale":"es_ES"}],"identifier":"54947","name":[{"value":"SECADORA_A_BAJA_TEMPERATURA","locale":"es_ES"}],"external_identifier":"599908054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Pico","name":[{"value":"Pico","locale":"es_ES"}],"external_identifier":"485160090","description":[{"value":"Pico","locale":"es_ES"}],"type_lookup":"1595"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":60.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":40.0,"a6zd77kj2mm2n4":{"identifier":"Lyocell","name":[{"value":"Lyocell","locale":"es_ES"}],"external_identifier":"467575090","description":[{"value":"Lyocell","locale":"it_IT"},{"value":"Lyocell","locale":"en_GB"},{"value":"Lyocell","locale":"es_ES"},{"value":"Lyocell","locale":"fr_FR"},{"value":"Lyocell","locale":"pt_PT"}],"type_lookup":"1633"},"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001524969560005(2022-04-27T04:15:32Z(2022-08-22T03:58:36Z(2022-08-15T22:00:01Z$001029340012664005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H109d36aa-082f-4612-9328-ff51683da0f1 DELETE<2023-09-02T17:15:42.936590199Z4dataloader-mongo-kafka-job62023-09-02T17:15:55.378687Z(mixer-gtin-agr-kfreeH17783660-aa8b-427f-b9a9-65678419de2062023-09-02T17:15:58.501637Z,mixer-gtin-calc-pcsflmH504b63bf-b9cf-4635-a982-cb9de4cb05c962023-09-02T17:16:00.903991Z,mixer-gtin-calc-pcsflmHad0741e7-fa0f-45b1-84b1-6591bda12e1f62023-09-03T02:43:23.336626Z0mixer-product-calc-kfreeH9685cafa-b81d-4049-bc69-c95b448cc6e3<2024-01-19T11:18:40.222216351Z$mixer-xsell-mixtriH6a1f7e7f-9428-4c56-ad7f-6ae313967d4362024-01-19T11:18:40.355934Z4mixer-packing-units-mixtriHaddd83e0-3144-4f6f-83d7-2a07b8eaf3a862024-01-19T11:18:51.320184Z.mixer-offer-badge-mixbiH83ad3631-3715-4f3c-b45b-f6f0e7f8f9d962024-01-19T11:25:59.585377Z.mixer-offer-badge-mixbiH5b6af51e-3af5-4aa8-82e5-c75f9b426a28(7×cIVA02IGIC91 +3047500102023-02-18T06:58:14.760Z01224220112001201COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001012220130475314&includeAsWebNovelty +es_ESNovedadDVD"2018-01-14T23:00Z5415153737638 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2014-10-29T00:32:41Z +es_ESMARCAS SPORT +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005415153737638$000001019241060314TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401497520466222312056 +LEVISmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/34/9/00001269349/00001269349872mM1011.jpg +es_ES Levi's +es_ESVaqueros999.8482560013 +es_ESVaqueros +6.000 +es_ES2014 Hombre999.2680805013 +es_ES Hombre +2.000 +es_ESModa999.53895013 +es_ESModaNNN +es_ESVaqueros999.39072585013 +es_ESVaqueros +7.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ESVaqueros999.2680936013 +es_ESVaqueros +6.000 +es_ES Hombre999.2680811013 +es_ES Hombre +1.000 +es_ES2014 Hombre999.2680805013 +es_ES Hombre +2.000 +es_ESModa999.53895013 +es_ESModaNNNNA11703759A12281519A11952285A11703723 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A110843530946442 +es_ES@LEVI STRAUSS & CO EUROPE, S.C.A. +es_ESJVaquero Slim-fit de hombre Levi's 510 +es_ESxVaquero modelo ajustado en color negro, con cinco bolsillos.A11084353222312056 +LEVIS +es_ES +LEVIS5490531600946442 +es_ES0LEVI STRAUSS EUROPE & COCALLE AV ARNAUD FRAITEUR, 15-23,..- B-1050 BRUSELAS - (REINO UNIDO) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize05510.05.14 +es_ESJVaquero Slim-fit de hombre Levi's 510 +es_ESJVaquero Slim-fit de hombre Levi's 510 +es_ESxVaquero modelo ajustado en color negro, con cinco bolsillos. calificacion1Acalificacion21Tcalificacion3RTcalificacion4VVcalificacion5VVcalificacion65100479307090 +40-42 +es_ES +40-42E +es_ESEspañol47923109031 +es_ES31477054090Americano +Talla47924009034 +es_ES34E +es_ESEspañol47924009034 +es_ES34477054090Americano +Tallapz3c2qg46aax5qpler4twpwa2rdqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02018-06-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02019-06-15T22:00:01.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02014-10-29T01:56:16.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYa5r36nvug7ald6 ENTITY{"identifier":"Slim","name":[{"value":"Slim","locale":"es_ES"}],"external_identifier":"7004305090","description":[{"value":"Slim","locale":"es_ES"}],"type_lookup":"1594"}MANYadla3f5bsg737w ENTITY{"identifier":"Joven Él","name":[{"value":"Joven Él","locale":"es_ES"}],"external_identifier":"372103090","description":[{"value":"Joven Él","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Vaqueros","name":[{"value":"Vaqueros","locale":"es_ES"}],"external_identifier":"347852090","description":[{"value":"Vaqueros","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Negro","color_description":[{"value":"Negro","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Negro","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png","size":"small"}],"description":[{"value":"Negro","locale":"es_ES"}],"identifier":"25525","name":[{"value":"COLOR_NEGRO","locale":"es_ES"}],"external_identifier":"599042054"},"identifier":"Negro","name":[{"value":"Negro","locale":"es_ES"}],"external_identifier":"347149090"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2014MANYawa5k5anmhgha2 ENTITY{"identifier":"Vaquero","name":[{"value":"Vaquero","locale":"es_ES"}],"external_identifier":"2656309090","description":[{"value":"Vaquero","locale":"es_ES"}],"type_lookup":"2501"}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001019241060314(2014-10-29T01:56:16Z(2019-06-15T22:00:01Z(2018-06-15T22:00:01Z$001012220130475314001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore314Hd1d2ff4b-9535-45ea-ab05-b620070688bc DELETE<2023-09-02T17:15:47.698316580Z4dataloader-mongo-kafka-job62023-09-02T17:15:54.876727Z(mixer-gtin-agr-kfreeH0b971caa-a0ec-4a06-86cb-0d87d034cd1b62023-09-02T17:15:57.307916Z,mixer-gtin-calc-pcsflmH544b4d70-6bb7-467c-bda4-74a5435bd03d62023-09-02T17:16:05.503903Z,mixer-gtin-calc-pcsflmH59b3afdc-d71c-4235-82c9-b33ccaeee64f62023-09-03T02:43:33.572842Z0mixer-product-calc-kfreeH327052cc-bd92-4262-8af2-0e9c558a682a<2024-01-19T11:18:40.302871589Z$mixer-xsell-mixtriHffab8bc4-5012-4860-977d-1ac2d0f85d8162024-01-19T11:18:40.365926Z4mixer-packing-units-mixtriH5b664a49-6dc8-465e-a9d3-10ae69483e3962024-01-19T11:18:51.320825Z.mixer-offer-badge-mixbiH7eb0e5a6-37e2-4ce7-b91a-c1c322145d8d62024-01-19T11:25:59.586647Z.mixer-offer-badge-mixbiH9109e551-9c53-4619-93b7-5d73c61fbacf(7×cIVA02IGIC91 +0848100102023-04-25T00:00:53.812Z032442861541001180COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001032418008481152"2021-11-17T23:00Z4065429274582 +Rosas +es_ES +Rosas +Rosas +es_ES +RosasMagenta +es_ESMagenta351246090 +es_ESColor Magenta599865054 +54216 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___54216O1.png +es_ESCOLOR_MAGENTA +es_ESColor MagentaMagenta +es_ESMagenta0(2022-06-21T15:26:12Z +es_ESG LIN FZ HD +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004065429274582$000001521467110152TRADICIONAL +es_ESCOLOR_MAGENTA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___54216O1.png2401817523528123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas  +es_ESDDeportes - Contenedor rebajas OI22997.44869638011 +es_ESDDeportes - Contenedor rebajas OI22N +es_ES&Sudaderas y Polares999.53669013 +es_ES&Sudaderas y Polares 25.000 +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ES Niños999.17368065013 +es_ES Niños +3.000 +es_ESRopa training999.52215013 +es_ESRopa training 20.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESSudaderas999.14731212013 +es_ESSudaderas +3.000 +es_ESRopa deportiva999.14566788013 +es_ESRopa deportiva +1.000 +es_ES Niños999.12406167013 +es_ES Niños +4.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESPDeportes - Contenedor 2as Rebajas OI2223997.45082266011 +es_ES:Contenedor 2as Rebajas OI2223N +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A417507045788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ESFSudadera de niña Essentials adidas +en_GBXA zip-up hoodie with sport-inspired comfort. +What's your colour? This juniors' adidas zip-up hoodie comes in many. And while its slim fit and minimalist style make this your daily go-to before heading out the door, it's really the soft, buttery touch of its French terry fabric that has you jumping for joy. This product is made with recycled content as part of our ambition to end plastic waste.Slim fit$Full zip with hoodSide pockets(Ribbed cuffs and hem +fr_FRzUne veste à capuche zippée confortable d'inspiration sport. +Quelle est ta couleur préférée ? Cette veste à capuche adidas junior est disponible en plusieurs versions. Sa coupe slim et son style minimaliste en font un indispensable de ta garde-robe, mais c'est la douceur de son molleton qui en feront ta pièce favorite. Ce produit est conçu à partir de matières recyclées, dans le cadre de notre lutte contre les déchets plastiques.Coupe slim.FZip sur toute la longueur. Capuche..Poches sur les côtés.6Base et poignets côtelés. +es_ES8Comodidad y estilo deportivo +¿Cuál es tu color favorito? Seguro que lo encuentras en esta chaqueta con capucha adidas para jóvenes activos. Su corte entallado y su estilo minimalista la convertirán en tu prenda favorita para llevar a diario, pero lo que más te va a gustar es el suave tejido de felpa, muy cómodo para acompañarte en todas tus actividades. Este producto se ha confeccionado con material reciclado como parte de nuestro compromiso por acabar con los residuos plásticos.Corte ajustadoPantalon avec poches latéralesjFabriqué avec du coton de l'initiative Better Cotton +es_ES El más pequeño de la casa no deja de moverse ni un solo segundo, por ello para que la comodidad le acompañe mientras deja volar su imaginación en las tardes de juegos en el parque, adidas Originals ha diseñado este chándal que está repleto de divertidos detalles en color. Formado por una sudadera con capucha y unos pantalones con bolsillos en los laterales, este conjunto de dos piezas deportivo tiene tal versatilidad, que podrás ponérselo tanto junto, como separado y combinado con cualquiera de las prendas de su armario. De tacto suave, se ha confeccionado con algodón sostenible de Better Cotton Initiative.(Sudadera con capuchaDPantalones con bolsillos laterales\Hecho con algodón de Better Cotton Initiative +pt_PT(Sweatshirt com capuz`Fabricada com algodão Better Cotton Iniciative.A39893527123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize HB9482 +es_ESFChándal de niños adidas Originals +es_ESFChándal de niños adidas Originals +en_GBThe youngest in the house doesn't stop moving for a single second, so to keep him comfortable while he lets his imagination run wild on playground afternoons, adidas Originals has designed this tracksuit that's packed with fun colourful details. Comprising a hoodie and trousers with side pockets, this sporty two-piece set is so versatile, he can wear it together or separately and mix and match with any of the items in his wardrobe. Soft to the touch, it's made from sustainable cotton from Better Cotton Initiative."Hooded sweatshirt4Trousers with side pocketsRMade with Better Cotton Initiative cotton +fr_FRLe petit dernier de la maison ne s'arrête jamais de bouger. Pour qu'il soit à l'aise lorsqu'il laisse libre cours à son imagination les après-midi de récréation, adidas Originals a conçu ce survêtement qui regorge de détails colorés amusants. Composé d'un sweat à capuche et d'un pantalon avec des poches latérales, ce deux-pièces sportif est si polyvalent qu'il peut le porter ensemble ou séparément et l'assortir à tout ce qu'il a dans sa garde-robe. Doux au toucher, il est fabriqué en coton durable issu de la Better Cotton Initiative.,Sweat-shirt à capuche>Pantalon avec poches latéralesjFabriqué avec du coton de l'initiative Better Cotton +es_ES El más pequeño de la casa no deja de moverse ni un solo segundo, por ello para que la comodidad le acompañe mientras deja volar su imaginación en las tardes de juegos en el parque, adidas Originals ha diseñado este chándal que está repleto de divertidos detalles en color. Formado por una sudadera con capucha y unos pantalones con bolsillos en los laterales, este conjunto de dos piezas deportivo tiene tal versatilidad, que podrás ponérselo tanto junto, como separado y combinado con cualquiera de las prendas de su armario. De tacto suave, se ha confeccionado con algodón sostenible de Better Cotton Initiative.(Sudadera con capuchaDPantalones con bolsillos laterales\Hecho con algodón de Better Cotton Initiative +pt_PT(Sweatshirt com capuz`Fabricada com algodão Better Cotton Iniciative. +calificacion1Acalificacion2Acalificacion4VVcalificacion5ADcalificacion6MO00N19970930903-4 Años +es_ES3-4 AñosE +es_ESEspañol1165209090 104 cm +es_ES 104 cm18171618090Fabricante +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02021-11-22T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-11-23T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-11-22T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Niños","name":[{"value":"Niños","locale":"es_ES"}],"external_identifier":"349990090","description":[{"value":"Niños","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Chándal","name":[{"value":"Chándal","locale":"es_ES"}],"external_identifier":"390449090","description":[{"value":"Chándal","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Chándal","name":[{"value":"Chándal","locale":"es_ES"}],"external_identifier":"2855564090","description":[{"value":"Chándal","locale":"es_ES"}],"type_lookup":"1599"}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001513992100104"2021-11-22T23:00ZDVD"2021-11-23T23:00Z"2021-11-22T23:00Z$001019710807314104001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore104H2722365a-4d77-4289-b777-952e329a3d95 DELETE<2023-09-02T17:35:11.503619029Z4dataloader-mongo-kafka-job62023-09-02T17:39:50.600541Z(mixer-gtin-agr-kfreeHba31cee5-105f-424d-b0b9-d8bf5162ec2d62023-09-02T17:50:41.943818Z,mixer-gtin-calc-pcsflmH6458bbc4-be9e-4d24-9f13-2c6b6f9cd76162023-09-02T17:50:42.912822Z,mixer-gtin-calc-pcsflmH2699ac9b-aa4c-4666-baff-b255041048e762023-09-03T02:55:22.363717Z0mixer-product-calc-kfreeH598ed928-603e-44bc-ba48-1551f20e65cf<2024-01-19T11:18:20.602441145Z$mixer-xsell-mixtriH2ee81515-1fa9-4c24-a4a6-f2b9d5e46e4562024-01-19T11:18:22.855668Z4mixer-packing-units-mixtriH0c4f3edf-ac82-49ff-bece-398e12a9131062024-01-19T11:18:25.423472Z.mixer-offer-badge-mixbiH49c474bd-d4e9-4fd3-b569-a9dd6b1c4c2e62024-01-19T11:21:22.200338Z.mixer-offer-badge-mixbiH857a1cf2-0789-4577-8e1f-df5d6bf28a5f8cn +$+ +}& Loffer(A45271304).publish_ends_extendedIVA02IGIC91 +00626001036043848062001301COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001036030100626042&includeAsWebNovelty +es_ESNovedadDVDMorados +es_ESMoradosMorados +es_ESMorados Morado +es_ES Morado347615090 +es_ES Morado5988330542332 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100827/___2332O1.png +es_ESCOLOR_MORADO +es_ESColor Morado Morado +es_ES Morado0(2022-09-29T10:56:43Z +es_ES*BRAGA BIKINI LISO BIC158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401853325025$000001536364580042TRADICIONAL +es_ESCOLOR_MORADO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100827/___2332O1.png240185332502527623655056ANDRES SARDA +es_ESAndrés Sardá +es_ES.Accesorios de lencería999.39091546013 +es_ES.Accesorios de lencería 26.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESTops de bikini999.39089970013 +es_ESTops de bikini +4.000 +es_ESBikinis999.39089965013 +es_ESBikinis +8.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A45271304 +es_ES.Accesorios de lencería999.39091546013 +es_ES.Accesorios de lencería 26.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0014468 +es_ES.VAN DE VELDE IBERICA SL +es_ES2Braga bikini liso bicolor +es_ES4Braga bikini liso bicolor.A4527130427623655056ANDRES SARDA +es_ESANDRES SARDA11633051600014468 +es_ES.VAN DE VELDE IBERICA SLxCALLE SANTA EULALIA,5-08012 BARCELONA - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize3411150 +es_ES2Braga bikini liso bicolor +es_ES2Braga bikini liso bicolor +es_ES4Braga bikini liso bicolor. +calificacion1Acalificacion2Acalificacion3M2calificacion4VVcalificacion5AH00N042E +es_ESEspañol042477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-26T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-27T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"No limpieza en seco","name":[{"value":"No limpieza en seco","locale":"es_ES"}],"external_identifier":"360095090","description":[{"value":"No limpieza en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No limpieza en seco","locale":"es_ES"}],"media_objects":[],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"704","name":[{"value":"NO_LIMPIEZA_EN_SECO","locale":"es_ES"}],"external_identifier":"18215300054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}ONEa4aig6savkv75m STRING[{"locale":"es_ES","value":"Sin cierre"},{"locale":"pt_PT","value":"Sem fecho"}]MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Tops de bikini","name":[{"value":"Tops de bikini","locale":"es_ES"}],"external_identifier":"40002164090","description":[{"value":"Tops de bikini","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYagio3trrjaqhgg ENTITY @NULL@{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliamida","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Bikinis","name":[{"value":"Bikinis","locale":"es_ES"}],"external_identifier":"8970133090","description":[{"value":"Bikinis","locale":"es_ES"}],"type_lookup":"1599"}ONEarte4uoeu4rkhe ENTITY{"identifier":"Braga normal","name":[{"value":"Braga normal","locale":"es_ES"}],"external_identifier":"2655622090","description":[{"value":"Braga normal","locale":"es_ES"}],"type_lookup":"2506"}ONEastcg34k65osv2 STRING[{"locale":"es_ES","value":"DREW"},{"locale":"pt_PT","value":"DREW"}]MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":73,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":20.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":7,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2023Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001536364580042"2022-09-27T22:00Z"2022-09-26T22:00Z$001036030100626042001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore042H9170daca-356b-4160-b6b8-daad5fed21a9 DELETE<2023-09-02T17:27:30.301875398Z4dataloader-mongo-kafka-job62023-09-02T17:27:39.584488Z(mixer-gtin-agr-kfreeHdd7e6753-72ef-424f-8a27-a3ca449be8fb62023-09-02T17:30:51.707259Z,mixer-gtin-calc-pcsflmHa2cef17d-d64e-4c1e-a281-b213f06ea7b462023-09-02T17:30:52.419666Z,mixer-gtin-calc-pcsflmHeba53a1a-56fc-47da-8ffd-cce4445c240562023-09-03T02:46:30.074068Z0mixer-product-calc-kfreeH0b533165-1514-4ae4-a1b6-9b8ec65a9a6e<2024-01-19T11:18:22.766546665Z$mixer-xsell-mixtriHde242084-e8b7-4329-a4eb-5f2f213cc77262024-01-19T11:18:22.922742Z4mixer-packing-units-mixtriH6a69e24a-e2f0-4c00-a1d9-84bec0761a3662024-01-19T11:18:25.430881Z.mixer-offer-badge-mixbiH774db7e7-c343-48e6-94ea-c96aca252e5962024-01-19T11:21:22.201582Z.mixer-offer-badge-mixbiH0c7debc9-6847-4287-a6df-53c6042a5bbe8cLoffer(A39753317).publish_ends_extendedIVA02IGIC91 +55640001015338965817001615COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001015361555640004"2021-05-09T22:00Z0723088099031Natural +es_ESNaturalNatural +es_ESNaturalTopo +es_ESTopo347961090 +es_ESTopo5992700543641 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___3641O2.png +es_ESCOLOR_TOPO +es_ESColor TopoTopo +es_ESTopo0"2021-05-10T12:33Z +es_ES&SHORT PACKABLE DOWN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000723088099031$000001513377480004TRADICIONAL +es_ESCOLOR_TOPO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___3641O2.png2401797898609896169056(MICHAEL MICHAEL KORS +es_ES(Michael Michael Kors +es_ESAbrigos999.39072580013 +es_ESAbrigos 13.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESPlumíferos999.39089882013 +es_ESPlumíferos +5.000 +es_ESAbrigos999.39072580013 +es_ESAbrigos 13.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A30938938 +es_ESPlumíferos999.39089882013 +es_ESPlumíferos +5.000 +es_ESAbrigos999.39072580013 +es_ESAbrigos 13.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0974303 +es_ESDeportes - Contenedor VVPP PV22997.42514389011 +es_ES(contenedor vvpp pv22N +es_ESDDeportes - Contenedor Rebajas PV22997.42771890011 +es_ES@contenedor rebajas deportes pv22N +es_ESLDeportes - Contenedor 2as rebajas pv22997.43004735011 +es_ES6contenedor 2as rebajas pv22N +es_ES Hombre999.17528256013 +es_ES Hombre +1.000 +es_ESRopa999.53820013 +es_ESRopa +3.000 +es_ESRunning999.53818013 +es_ESRunning 16.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES0Entrena con Under Armour997.42246959011 +es_ES0Entrena con Under Armour +2.000 +es_ESFDeportes - Especial Deportes - PV22997.42246957011 +es_ES,Especial Deportes PV22NN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A409133800901922 +es_ESVShort de hombre Iso-Chill 2in1 Under Armour +es_ESHemos alisado las fibras y añadido algunas innovaciones para crear un tejido revolucionario que capilarice rápidamente el sudor para aportarte frescura y tranquilidad, y que puedas rendir al máximo.Tejido exterior ligero y elástico para una comodidad y una durabilidad superiores. Tejido de malla Iso-Chill en el pantalón corto de compresión integrado que ayuda a dispersar el calor corporal y ofrece frescura al tacto. Confección con tejido elástico en 4 direcciones que permite una mayor movilidad en cualquier dirección. Material que capilariza el sudor y se seca rápidamente. Cintura de punto plana con cordón interiorA40913380136537056UNDER ARMOUR +es_ESUNDER ARMOUR8803251600901922 +es_ESFUNDER ARMOUR EUROPE B.V._recargaNFTrCALLE STADIONPLEIN,10- AMSTERDAM -1076 - (PAISES BAJOS) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize1364858-899 +es_ESVShort de hombre Iso-Chill 2in1 Under Armour +es_ESVShort de hombre Iso-Chill 2in1 Under Armour +es_ESHemos alisado las fibras y añadido algunas innovaciones para crear un tejido revolucionario que capilarice rápidamente el sudor para aportarte frescura y tranquilidad, y que puedas rendir al máximo.Tejido exterior ligero y elástico para una comodidad y una durabilidad superiores. Tejido de malla Iso-Chill en el pantalón corto de compresión integrado que ayuda a dispersar el calor corporal y ofrece frescura al tacto. Confección con tejido elástico en 4 direcciones que permite una mayor movilidad en cualquier dirección. Material que capilariza el sudor y se seca rápidamente. Cintura de punto plana con cordón interior calificacion1Acalificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO06N479439090M +es_ESME +es_ESEspañol479439090M +es_ESM477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-12-31T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-01-01T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-12-31T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Shorts","name":[{"value":"Shorts","locale":"es_ES"}],"external_identifier":"347853090","description":[{"value":"Shorts","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Shorts","name":[{"value":"Shorts","locale":"es_ES"}],"external_identifier":"2836854090","description":[{"value":"Shorts","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliéster","locale":"es_ES"},{"value":"Poliéster","locale":"pt_PT"},{"value":"Polyester","locale":"fr_FR"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliestere","locale":"it_IT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":100.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517611200050"2021-12-31T23:00ZDVD"2022-01-01T23:00Z"2021-12-31T23:00Z$001010422102433050001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore050Ha72bbdec-57bb-40a2-a5c9-9117c26b0968 DELETE<2023-09-02T17:34:37.476727388Z4dataloader-mongo-kafka-job62023-09-02T17:38:21.604860Z(mixer-gtin-agr-kfreeH4a0256c0-579a-49e3-8f9a-923a1f9d739562023-09-02T17:50:42.710835Z,mixer-gtin-calc-pcsflmHbd4dfc8b-dd6b-4652-a639-e4b111749b6462023-09-02T17:50:52.117518Z,mixer-gtin-calc-pcsflmH13b5dfae-b674-4a1a-abd4-72a7489fffaf62023-09-03T02:55:19.974516Z0mixer-product-calc-kfreeH1da9d8f0-b2eb-4559-95cd-48df57574b54<2024-01-19T11:18:25.810546079Z$mixer-xsell-mixtriHc44297a4-ec83-405e-8035-fdc0cb379efa62024-01-19T11:18:25.870531Z4mixer-packing-units-mixtriH889b3216-6f0e-41ee-91a1-caa72cbf699462024-01-19T11:18:26.125506Z.mixer-offer-badge-mixbiH4239954b-c66c-4485-8b4e-45943847e90962024-01-19T11:21:22.303791Z.mixer-offer-badge-mixbiHe26008ef-7ccc-4ed2-b671-039adf177d7bҠ8cLoffer(A41404794).publish_ends_extendedIVA02IGIC92 +66918001006240427370001193COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001006219366918 &includeAsWebNovelty +es_ESNovedadDVD"2021-10-25T22:00Z2062193669189 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2021-10-13T09:03:31Z +es_ES*MONEDERO BILLETERO BR158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401814073989$000000000151973552TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401814073989862847056 YANCCI +es_ES Yancci  +es_ES(Carteras y monederos999.39072368013 +es_ES(Carteras y monederos +3.000 +es_ESAccesorios999.39072300013 +es_ESAccesorios +4.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESAccesorios997.41961634011 +es_ESAccesorios +4.000 +es_ESModa Mujer997.41875780011 +es_ESModa Mujer 32.000 +es_ES,Cross - Contenedor 8DO997.41837795011 +es_ESContenedor 8DOCDNN +es_ES&Accesorios y bolsos997.38842150011 +es_ES&Accesorios y bolsos +8.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESCarteras999.39072372013 +es_ESCarteras +2.000 +es_ES(Carteras y monederos999.39072368013 +es_ES(Carteras y monederos +3.000 +es_ESAccesorios999.39072300013 +es_ESAccesorios +4.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ES Accesorios mujer997.18820067011 +es_ES Accesorios mujer +1.000 +es_ES:Moda_Accesorios Made in Spain997.18819669011 +es_ES0Accesorios Made in SpainCDN +es_ES.Rebajas Accesorios PV22997.42788192011 +es_ES.Rebajas accesorios PV22 +1.000 +es_ESNIKE RETAIL SUCURSAL EN ESPAÑACALLE AV BAIX LLOBREGAT.P.NEG.M.BLAU,5-7-08820 EL PRAT DE LLOBREGAT - BARCELONA (ESPAñA)  +es_ES`Zapatillas casual de mujer Air Jordan 1 Mid Nike +en_GBThe Air Jordan 1 Mid brings full-court style and premium comfort to an iconic look. Its Air-Sole unit cushions play on the hardwood, while the padded collar gives you a supportive feel.Premium leather and synthetic upper provides durability, comfort and support.pAir-Sole unit in the heel delivers signature cushioning.pRubber outsole offers traction on a variety of surfaces. +es_ESFEstilo clásico y comodidad premiumLas Air Jordan 1 Mid llevan todo el estilo del baloncesto y la comodidad más premium a un look icónico. Su unidad Air-Sole amortigua cada pisada que das sobre el parqué, al tiempo que la zona del tobillo acolchada aporta más sujeción. Parte superior de piel premium y material sintético para más durabilidad, comodidad y sujeción. Unidad Air-Sole en el talón para una amortiguación distintiva. Suela exterior de goma para una mayor tracción en distintos tipos de superficies.A3920331732769615056NIKE +es_ESNIKE5965801600998229 +es_ESCross - Limite 48 horas Fase II997.26300411011 +es_ES$Límite 48 horas 2CDNN26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42002599 +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN0901922 +es_ES0UNDER ARMOUR EUROPE B.V. +es_ESbCamiseta de hombre HeatGear® Fitted Under Armour +es_ES Las prendas HeatGear® Armour son nuestras prendas interiores de alto rendimiento clásicas: aquellas que te pones antes que nada y te quitas al final. Ahora son más cómodas, porque capilarizan el sudor. Además, hemos añadido elasticidad para que puedas moverte hagas lo que hagas.Tejido HeatGear® superligero que ofrece una protección superior sin añadir pesoPaneles de malla en las axilas y la parte posterior que proporcionan una ventilación estratégicanMaterial que capilariza el sudor y se seca rápidamenteDiseño ergonómico que mantiene las costuras alejadas de las zonas de mayor abrasión y aumenta la durabilidadDiseño híbrido de mangas raglán para ofrecer mayor libertad de movimiento y comodidadA42002599136537056UNDER ARMOUR +es_ESUNDER ARMOUR8803251600901922 +es_ES0UNDER ARMOUR EUROPE B.V.rCALLE STADIONPLEIN,10- AMSTERDAM -1076 - (PAISES BAJOS) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize1361683-690 +es_ESbCamiseta de hombre HeatGear® Fitted Under Armour +es_ESbCamiseta de hombre HeatGear® Fitted Under Armour +es_ES Las prendas HeatGear® Armour son nuestras prendas interiores de alto rendimiento clásicas: aquellas que te pones antes que nada y te quitas al final. Ahora son más cómodas, porque capilarizan el sudor. Además, hemos añadido elasticidad para que puedas moverte hagas lo que hagas.Tejido HeatGear® superligero que ofrece una protección superior sin añadir pesoPaneles de malla en las axilas y la parte posterior que proporcionan una ventilación estratégicanMaterial que capilariza el sudor y se seca rápidamenteDiseño ergonómico que mantiene las costuras alejadas de las zonas de mayor abrasión y aumenta la durabilidadDiseño híbrido de mangas raglán para ofrecer mayor libertad de movimiento y comodidad calificacion1Acalificacion2Acalificacion3HTcalificacion4VVcalificacion5AAcalificacion6MO06N479443090S +es_ESSE +es_ESEspañol479443090S +es_ESS477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-03T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-19T03:16:07.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-07-25T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"351059090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":90.0},{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":10.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001522519190048"2022-07-25T22:00Z(2022-09-19T03:16:07Z"2022-08-03T22:00Z$001010410745516048001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore048H7046287e-d08a-47cc-9abe-c0068a752f3b DELETE<2023-09-02T17:23:58.411401242Z4dataloader-mongo-kafka-job62023-09-02T17:24:06.301763Z(mixer-gtin-agr-kfreeH1f73d71b-e352-4576-875b-588fa3f484ef62023-09-02T17:24:31.018721Z,mixer-gtin-calc-pcsflmH1deca9a8-c49c-44bb-ae02-15cbb761a09562023-09-02T17:24:32.121298Z,mixer-gtin-calc-pcsflmH9db9d45d-0923-421b-bf99-4ba0264e06a262023-09-03T02:39:41.152951Z0mixer-product-calc-kfreeH350ea1cd-6adf-4956-afbf-a54c563a7473<2024-01-19T11:18:00.375785995Z$mixer-xsell-mixtriHc1b4c145-df2a-4a60-baaf-258f9b0f9a6a62024-01-19T11:18:00.419160Z4mixer-packing-units-mixtriH5500d1ad-2696-465d-adda-5f5a4becc84262024-01-19T11:18:26.919444Z.mixer-offer-badge-mixbiH6b5b9c11-7a35-44e4-904a-b30c36d6832662024-01-19T11:21:23.599026Z.mixer-offer-badge-mixbiH837cebf0-81b5-44dd-9b03-5a8b96f513ee蠙8cn +$+ +}&̝Loffer(A43270142).publish_ends_extendedIVA02IGIC91 +03488001086541941516001684(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001086568403488106&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31820072090 +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31855841054 +11935 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png +es_ESFCERTIFICACION_OEKO-TEX_STANDARD_100 +es_ESHCertificación Oeko-tex Standard 100 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png002 +es_ESHCertificación Oeko-tex Standard 1008SUSTAINABILITY_MANUFACTURING"2022-01-03T23:00Z8445470025450Multicolor +es_ESMulticolorMulticolor +es_ESMulticolorMulticolor +es_ESMulticolor352633090 +es_ESMulticolor598507054 +20205 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png +es_ES6COLOR_MULTICOLOR_SECUNDARIO +es_ES6Color Multicolor SecundarioMulticolor +es_ESMulticolor0(2022-03-18T09:14:25Z +es_ES*CAMISETA PUNTO "ANIMA156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008445470025450$000001523972110106TRADICIONAL +es_ES6COLOR_MULTICOLOR_SECUNDARIO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png24018236637372797250056 BOBOLI +es_ES Boboli +es_ESCamisetas999.39089905013 +es_ESCamisetas +4.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN +es_ESCamisetas999.39072599013 +es_ESCamisetas +1.000 +es_ES"Camisetas y Polos999.39072598013 +es_ES"Camisetas y Polos 10.000 +es_ESBebé Niño999.39073122013 +es_ESBebé Niño +4.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN001086568602949001086568602956001086568201866001086568603012156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43270142 +es_ESCamisetas999.39089905013 +es_ESCamisetas +4.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN5301871600618645 +es_ESBOBOLI, S.A.CALLE CL DE LA FISICA,A7 LLINARDS PK,18-08450 LLINARS DEL VALLES - BARCELONA (ESPAñA)  +es_ESTCamiseta punto de niño estampado animales +es_ESCamiseta de niño de punto liso flamé con estampado camuflaje de animales y plantas en varios colores. El cuello es de canalé en color kaki. En el pecho lleva un bolsillo con tapeta en color kaki. Lleva como detalle una etiqueta de la marca. Disponible de la talla 6 meses a 6 años.A432701422797250056 BOBOLI +es_ES BOBOLI5301871600618645 +es_ESBOBOLI, S.A.CALLE CL DE LA FISICA,A7 LLINARDS PK,18-08450 LLINARS DEL VALLES - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize 334077 +es_ESTCamiseta punto de niño estampado animales +es_ESTCamiseta punto de niño estampado animales +es_ESCamiseta de niño de punto liso flamé con estampado camuflaje de animales y plantas en varios colores. El cuello es de canalé en color kaki. En el pecho lleva un bolsillo con tapeta en color kaki. Lleva como detalle una etiqueta de la marca. Disponible de la talla 6 meses a 6 años. +calificacion1Acalificacion2Acalificacion3M1calificacion4VVcalificacion5VV00N4793900906 Meses +es_ES6 MesesE +es_ESEspañol4793900906 Meses +es_ES6 Meses477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRING(Fin Campaña PV22 BBONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-04-22T00:16:41.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-30T22:00:01.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-04-22T00:16:41.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Fantasía","name":[{"value":"Fantasía","locale":"es_ES"}],"external_identifier":"25521449090","description":[{"value":"Fantasía","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"351059090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001523972110106(2022-04-22T00:16:41Z(2022-08-30T22:00:01Z(2022-04-22T00:16:41Z$001086568403488106001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore10608Ha8dbe791-b7ba-4e7e-b175-696cca3770d2 DELETE<2023-09-02T17:18:00.367393043Z4dataloader-mongo-kafka-job62023-09-02T17:18:09.350858Z(mixer-gtin-agr-kfreeH1703be80-d309-4c1a-8a9c-85ffd0548b1962023-09-02T17:18:19.114358Z,mixer-gtin-calc-pcsflmH8b8e29ff-259a-4011-87ce-34b4ca5f333762023-09-02T17:18:20.508941Z,mixer-gtin-calc-pcsflmH1d3a0df7-034c-407e-9587-f64eb2aef55c62023-09-03T02:39:51.376784Z0mixer-product-calc-kfreeH7f883afd-4023-470b-96a7-f2ba6775179c<2024-01-19T11:18:00.393408419Z$mixer-xsell-mixtriH8f16e966-3a0a-49f1-93e9-3c2aff5d90dd62024-01-19T11:18:00.425150Z4mixer-packing-units-mixtriH84a3924e-f042-46ac-bf1b-efc0719bab5c62024-01-19T11:18:26.920446Z.mixer-offer-badge-mixbiHa55b57f5-86b6-4c63-b2b4-bbd13b92a20e62024-01-19T11:21:23.599888Z.mixer-offer-badge-mixbiH81f2802d-c540-4140-bd03-547d27a82fccꠙ8cIVA02IGIC91 +0089800102023-01-19T04:47:56.162Z041231708620001640COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001041264000898014&includeAsWebNovelty +es_ESNovedadDVD"2019-04-15T22:00Z0500023466260Naranjas +es_ESNaranjasNaranjas +es_ESNaranjasNaranja +es_ESNaranja347412090 +es_ESNaranja596745054 +10150 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___10150O4.png +es_ESCOLOR_NARANJA +es_ESColor NaranjaNaranja +es_ESNaranja0(2019-04-22T16:21:45Z +es_ES BOYBERMUDA PLANA +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000500023466260$000001476081270014TRADICIONAL +es_ESCOLOR_NARANJA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___10150O4.png2401703923579894121056GAP +es_ESGap +es_ES$PantalonesBermudas999.2680963013 +es_ES*Pantalones y Bermudas +1.000 +es_ES$Niño (1-16 años)999.2680820013 +es_ES$Niño (1-16 años) +3.000 +es_ES2014 Infantil999.2680809013 +es_ESInfantil +3.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ESBermudas999.39089916013 +es_ESBermudas 15.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A285849710809178 +es_ES$GAP EUROPE LIMITED +es_ESJBermuda cargo de niño Gap en naranja +es_ESBermuda tipo cargo en color naranja, con elástico en la cintura y cordón para ajustar. Lleva varios bolsillos de distinto tipo.A28584971894121056GAP +es_ESGAP5367831600809178 +es_ES$GAP EUROPE LIMITED|CALLE 103 WIGMORE STREET, W1U 1QS,..- LONDON - (REINO UNIDO) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize 440064 +es_ESJBermuda cargo de niño Gap en naranja +es_ESJBermuda cargo de niño Gap en naranja +es_ESBermuda tipo cargo en color naranja, con elástico en la cintura y cordón para ajustar. Lleva varios bolsillos de distinto tipo. +calificacion1F0calificacion2Acalificacion3RPcalificacion4VVcalificacion5VV0047912709014 Años +es_ES14 AñosE +es_ESEspañol479450090XXL +es_ESXXL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-09-07T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-09-08T22:00:00.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02019-04-19T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar a mano máximo 30º C.","name":[{"value":"Lavar a mano máximo 30º C.","locale":"es_ES"}],"external_identifier":"16122336090","description":[{"value":"Lavar a mano máximo 30º C.","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bermudas","name":[{"value":"Bermudas","locale":"es_ES"}],"external_identifier":"352535090","description":[{"value":"Bermudas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones y Bermudas","name":[{"value":"Pantalones y Bermudas","locale":"es_ES"}],"external_identifier":"2700611090","description":[{"value":"Pantalones y Bermudas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2019Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001476081270014"2019-04-19T22:00Z"2019-09-08T22:00Z"2019-09-07T22:00Z$001041264000898014001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore014Hb4381868-e3c0-454a-baf0-2711cf3e9cdd DELETE<2023-09-02T17:05:32.689884517Z4dataloader-mongo-kafka-job62023-09-02T17:05:52.254723Z(mixer-gtin-agr-kfreeHa39ee480-d8d3-4e91-ad94-c0d156e3efb262023-09-02T17:06:16.016629Z,mixer-gtin-calc-pcsflmHec4c6464-3b37-4080-9003-f6af5546d1cf62023-09-02T17:06:20.003835Z,mixer-gtin-calc-pcsflmH2408c55a-1ef8-46ba-9c1b-3448145df71f62023-09-03T02:20:55.893585Z0mixer-product-calc-kfreeH2b5cb6e4-2bbb-4e1c-971b-fb0f3b94b906<2024-01-19T11:18:00.362900310Z$mixer-xsell-mixtriHca8b904c-5a57-4f9f-a498-c99cfe483aaa62024-01-19T11:18:00.473898Z4mixer-packing-units-mixtriH6ab456f1-eab8-47df-a4ae-d7adb82772f062024-01-19T11:18:26.920971Z.mixer-offer-badge-mixbiHb7eb94c4-c26e-4a40-8dbe-fb56e961599162024-01-19T11:21:23.600664Z.mixer-offer-badge-mixbiH2531b872-0949-4abc-b6fb-d74d84345326젙8cLoffer(A41608925).publish_ends_extendedIVA02IGIC91 +05619001003041088675001531COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001003053105619400"2021-11-02T23:00Z0196108036307Marrones +es_ESMarronesMarrones +es_ESMarronesMarrón +es_ESMarrón344718090 +es_ESMarrón5995980544536 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4536O3.png +es_ESCOLOR_MARRON +es_ESColor MarrónMarrón +es_ESMarrón0(2021-12-23T16:39:58Z +es_ES*ZAPATO TACON SALON KE158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000196108036307$000001520712500400TRADICIONAL +es_ESCOLOR_MARRON +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4536O3.png2401816140702896169056(MICHAEL MICHAEL KORS +es_ES(Michael Michael Kors +es_ESZapatos N997.2180011 +es_ES"Zapatos de fiesta 18.000 +es_ESFiesta Mujer997.2143011 +es_ESFiesta MujerCDN +es_ESCóctel997.2995349011 +es_ESCóctel 64.000 +es_ESFiesta Mujer997.2143011 +es_ESFiesta MujerCDN +es_ES"Zapatos de salón999.39073052013 +es_ES"Zapatos de salón 10.000 +es_ESZapatos999.39072676013 +es_ESZapatos +2.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ES.Rebajas Accesorios PV22997.42788192011 +es_ES.Rebajas accesorios PV22 +1.000 +es_ESCross - Contenedor Noches Flash997.40995448011 +es_ES.Contenedor Noches FlashCDNNN +es_ESModa mujer997.44571721011 +es_ESModa mujer 21.000 +es_ES30997.39154516011 +es_ES30 +4.000 +es_ESjCross - Contenedor Venta Privada NO Acumulable OI2223997.39128268011 +es_ESLContenedor Venta Privada no acumulableCDNN +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESRopa mujer997.44306142011 +es_ESRopa mujer +1.000 +es_ESXCross - Contenedor 2022 Black Friday Moda 30997.44305665011 +es_ES(Black Friday Moda 30CDN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42169636 +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN4867851600046193 +es_ES8RALPH LAUREN ESPAÑA, S.L.U.vCALLE CL SERRANO,26-3º,..-28001 MADRID - MADRID (ESPAñA)  +es_ESRCamisa de mujer de lino con mangas dolman +es_ESEsta camisa de lino, diseñada con mangas dolman cortas y puños con vuelta, le da un toque moderno a una prenda básica inspirada en la ropa de hombre. Relaxed Fit. Su longitud está pensada para que quede a la cadera. La talla M tiene 73,7 cm de longitud del cuerpo trasero. Cuello de punta. Tapeta de botones en el centro de la parte delantera. Manga dolman corta con bordes con doble vuelta. Canesú trasero con tabla. Dobladillo irregular más largo por detrás. Lino. Lavar en seco. Artículo de importación. La modelo mide 1,78 m y lleva la talla S.A42169636124200056 LAUREN +es_ES LAUREN4867851600046193 +es_ES8RALPH LAUREN ESPAÑA, S.L.U.vCALLE CL SERRANO,26-3º,..-28001 MADRID - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize200699152 +es_ESRCamisa de mujer de lino con mangas dolman +es_ESRCamisa de mujer de lino con mangas dolman +es_ESEsta camisa de lino, diseñada con mangas dolman cortas y puños con vuelta, le da un toque moderno a una prenda básica inspirada en la ropa de hombre. Relaxed Fit. Su longitud está pensada para que quede a la cadera. La talla M tiene 73,7 cm de longitud del cuerpo trasero. Cuello de punta. Tapeta de botones en el centro de la parte delantera. Manga dolman corta con bordes con doble vuelta. Canesú trasero con tabla. Dobladillo irregular más largo por detrás. Lino. Lavar en seco. Artículo de importación. La modelo mide 1,78 m y lleva la talla S. +calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5BPDN47936309050 +es_ES50E +es_ESEspañol479445090XL +es_ESXL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa2ynyjkfoo2woqTIMESTAMP02098-12-31T23:00:01.000ZONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02018-12-31T23:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-29T22:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-02-24T04:44:08.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º en programa delicado","name":[{"value":"Lavar máximo 30º en programa delicado","locale":"es_ES"}],"external_identifier":"484883090","description":[{"value":"Lavar máximo 30º en programa delicado","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMáximoTreinta programa delicado","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___11924O1.png","size":"small"}],"description":[{"value":"Lavar máximo a 30º en programa delicado","locale":"es_ES"}],"identifier":"11924","name":[{"value":"LAVARMAXIMOTREINTA_PROGRAMA_DELICADO","locale":"es_ES"}],"external_identifier":"597000054"}} {"identifier":"Lavar máximo 30º en programa delicado","name":[{"value":"Lavar máximo 30º en programa delicado","locale":"es_ES"}],"external_identifier":"484883090","description":[{"value":"Lavar máximo 30º en programa delicado","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMáximoTreinta programa delicado","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___11924O1.png","size":"small"}],"description":[{"value":"Lavar máximo a 30º en programa delicado","locale":"es_ES"}],"identifier":"11924","name":[{"value":"LAVARMAXIMOTREINTA_PROGRAMA_DELICADO","locale":"es_ES"}],"external_identifier":"597000054"}} {"identifier":"Lavar máximo 30º en programa delicado","name":[{"value":"Lavar máximo 30º en programa delicado","locale":"es_ES"}],"external_identifier":"484883090","description":[{"value":"Lavar máximo 30º en programa delicado","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMáximoTreinta programa delicado","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___11924O1.png","size":"small"}],"description":[{"value":"Lavar máximo a 30º en programa delicado","locale":"es_ES"}],"identifier":"11924","name":[{"value":"LAVARMAXIMOTREINTA_PROGRAMA_DELICADO","locale":"es_ES"}],"external_identifier":"597000054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Camisas","name":[{"value":"Camisas","locale":"es_ES"}],"external_identifier":"347642090","description":[{"value":"Camisas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}MANYagio3trrjaqhgg ENTITY{"identifier":"Tela","name":[{"value":"Tela","locale":"es_ES"}],"external_identifier":"477974090","description":[{"value":"Tela","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas, Blusas y Tops","name":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"external_identifier":"2700640090","description":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Lino","name":[{"value":"Lino","locale":"es_ES"}],"external_identifier":"347685090","description":[{"value":"Lino","locale":"it_IT"},{"value":"Linen","locale":"en_GB"},{"value":"Lino","locale":"es_ES"},{"value":"Lin","locale":"fr_FR"},{"value":"Linho","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001523385020010(2022-02-24T04:44:08Z(2022-08-29T22:00:01Z(2018-12-31T23:00:01Z$001023631205863010001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore010H7a5492a2-ee77-48f3-a704-7aac9d6cc361 DELETE<2023-09-02T17:18:33.909404506Z4dataloader-mongo-kafka-job62023-09-02T17:18:46.061789Z(mixer-gtin-agr-kfreeHfba053f3-c17c-4df5-8a5c-411f3fe605f562023-09-02T17:18:53.702048Z,mixer-gtin-calc-pcsflmH3eb67094-4356-4518-88b8-19974e1a337a62023-09-02T17:18:57.210951Z,mixer-gtin-calc-pcsflmH29f861f3-5134-4ae5-8e71-d967ef22a3f362023-09-02T22:40:23.643928Z0mixer-product-calc-kfreeH326d971a-8e56-421a-930a-e13c49985b37<2024-01-19T11:18:24.120761653Z$mixer-xsell-mixtriHf05e046e-e8ed-49d0-b8e6-50547f3a8e6062024-01-19T11:18:24.220781Z4mixer-packing-units-mixtriHa3186c54-459b-4f93-82f0-0fa96159004862024-01-19T11:18:27.333400Z.mixer-offer-badge-mixbiH2dd1e781-28a5-4f4b-a98a-d183f52d2a8f62024-01-19T11:21:23.605153Z.mixer-offer-badge-mixbiH91f448f6-81b1-4024-a4ed-4a26b04cd4bd8cIVA02IGIC92 +3288000102023-03-21T03:04:00.723Z00515862973001121COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001005112132880 "2014-12-09T23:00Z0731454431828"2014-12-09T23:00Z20511213288090(2014-12-30T09:21:46Z +es_ES*OUT OF THE GHETTO-THE +es_ES Discos274975090 Discos395ML +es_ESml +1.0000731454431828$0000000001073044902401542313548200396056SPECTRUM +es_ESSPECTRUM +es_ESSoul-Funk-R&B999.5224823013 +es_ESSoul-Funk-R&B +1.000 +es_ESSoul-Funk-R&B999.54213013 +es_ESSoul-Funk-R&B +9.000 +es_ESMúsica999.54175013 +es_ESMúsicaNNN +es_ES Discos274975090 Discos395A140919866253011600565341 +es_ES2UNIVERSAL MUSIC SPAIN SLUjCALLE TORRELAGUNA,64-28043 MADRID - MADRID (ESPAñA)  +es_ESTOut of the ghetto - The polydor years (CD)A140919866253011600565341 +es_ES2UNIVERSAL MUSIC SPAIN SLUjCALLE TORRELAGUNA,64-28043 MADRID - MADRID (ESPAñA) 998.00078 +es_ESMúsica998.00077 +es_ESMúsica998 +es_ES@Jerarquía de Ficha de Productos0731454431828 +es_ESTOut of the ghetto - The polydor years (CD) +es_ESTOut of the ghetto - The polydor years (CD) +calificacion1Acalificacion2Ocalificacion3M5calificacion4VVcalificacion5B06pler4twpwa2rdqpotazgohmkmafk MANYa5hilbj32lamhqCOMPLEX {"apj2uzph6fmmkk":1,"avgcdiqt7a2aza":{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"346108090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"727"},"acmt6g7r6qhx2u":[{"au7f4xdiq7un2c":"Moonlight lovin' (menage a trois)","a4ry3szh3gtire":1},{"au7f4xdiq7un2c":"Don't let me be lonely tonight","a4ry3szh3gtire":2},{"au7f4xdiq7un2c":"What does it take","a4ry3szh3gtire":3},{"au7f4xdiq7un2c":"Don't let go","a4ry3szh3gtire":4},{"au7f4xdiq7un2c":"Zeke the freak","a4ry3szh3gtire":5},{"au7f4xdiq7un2c":"Out of the ghetto","a4ry3szh3gtire":6},{"au7f4xdiq7un2c":"It's heaven to me","a4ry3szh3gtire":7},{"au7f4xdiq7un2c":"A few more kisses to go","a4ry3szh3gtire":8},{"au7f4xdiq7un2c":"I ain't never","a4ry3szh3gtire":9},{"au7f4xdiq7un2c":"It's all in the game","a4ry3szh3gtire":10},{"au7f4xdiq7un2c":"Love has been good to us","a4ry3szh3gtire":11}]}ONEafo2anbgjhsm24 STRINGz[{"locale":"es_ES","value":"DANCE ELECTRONICA SOUL HIP-HOP"}]ONEagicfmz77ja53a STRINGf[{"locale":"es_ES","value":"SOUL/FUNK/DISCOSOUND"}]ONEahfff3nxlhwulu STRINGDSONEajpdzknt6uts6y ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"347028090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"755"}MANYal3xisuwvftmyk ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"10121506090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"910"}ONEaoebsmn4ezopnm STRING001ONEap2hatgiudxb3e STRING:OUT OF THE GHETTO-THE POLYDORONEap7y5h3tps6gkg STRING012MANYaqrilmr6vaykxs NUMBER1ONEara2vukzeq2ngmTIMESTAMP02014-12-09T23:00:00.000ZONEarnjhlabcabx7u STRING001MANYav6kjmaio2grso ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"347028090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"755"}ONEav7wm2uhmbgqwk STRINGHAYES, ISAACMANYavajjx54jfzn6kCOMPLEX{"agpvq6oxw255wq":[{"ao2qh3g5n6csh4":{"identifier":"010145","name":[{"value":"Hayes, Isaac","locale":"es_ES"}],"external_identifier":"209675055","given_name":"Hayes, Isaac"}}],"aelpy27erl64ea":{"identifier":"Artista","name":[{"value":"Artista","locale":"es_ES"}],"external_identifier":"42203958090","description":[{"value":"Artista","locale":"es_ES"}],"type_lookup":"732"}}MANY*musica_iss_calculatedCOMPLEX{"name":"Hayes, Isaac","rol":"Artista","grouper":"musicCast","normalize_name_grouper":"musicCast|hayes,-isaac"}Musica_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02018-05-19T22:46:11.000ZONEafabpb3cbt6g3oTIMESTAMP02018-06-30T22:00:01.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02014-12-30T09:23:31.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000107304490(2014-12-30T09:23:31Z(2018-06-30T22:00:01Z(2018-05-19T22:46:11Z$001005112132880 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hd90fbbe4-a1a3-4934-a849-5067959e7b8d DELETE<2023-09-02T17:25:07.839105109Z4dataloader-mongo-kafka-job62023-09-02T17:25:20.968421Z(mixer-gtin-agr-kfreeH469fc2ae-d654-46ec-977c-67700d6c331f62023-09-02T17:27:15.814334Z,mixer-gtin-calc-pcsflmHd913a027-f946-4b57-9ed0-8a074fc4c15a62023-09-02T17:27:17.504962Z,mixer-gtin-calc-pcsflmHbaf03f07-dd47-474d-8266-4b785aa088eb62023-09-03T02:54:32.969555Z0mixer-product-calc-kfreeHf43cf389-d96a-4f38-87cc-47e17f27662a<2024-01-19T11:18:24.882991331Z$mixer-xsell-mixtriH3557f4ff-ae6b-4387-8f28-847933e9b39062024-01-19T11:18:25.010435Z4mixer-packing-units-mixtriH0c4cbd06-0e15-488e-8bc4-09ad6b023bb562024-01-19T11:18:27.037087Z.mixer-offer-badge-mixbiHd2682a26-aaa4-443d-882f-3de1c52e4c0d62024-01-19T11:21:27.406626Z.mixer-offer-badge-mixbiH15eec8a2-fbec-49e0-836c-b4e02be23c1c8ǢcLoffer(A42862758).publish_ends_extendedIVA02IGIC91 +01072001035841785511001132(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001035813201072085&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31820072090 +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31855841054 +11935 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png +es_ESFCERTIFICACION_OEKO-TEX_STANDARD_100 +es_ESHCertificación Oeko-tex Standard 100 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png002 +es_ESHCertificación Oeko-tex Standard 1008SUSTAINABILITY_MANUFACTURING"2022-02-15T23:00Z3100052926611 Azules +es_ES Azules Azules +es_ES AzulesAzul claro +es_ESAzul claro347926090 +es_ESAzul Claro5994450544237 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___4237O2.png +es_ES COLOR_AZUL_CLARO +es_ES Color Azul ClaroAzul claro +es_ESAzul claro0(2022-03-03T11:21:26Z +es_ESTRIANGLE158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003100052926611$000001525997070085TRADICIONAL +es_ES COLOR_AZUL_CLARO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___4237O2.png2401829113243345176056 LEJABYmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA01/201306/12/1347358763_3_.jpg +es_ESMaison Lejaby +es_ESModa mujer997.44571721011 +es_ESModa mujer 21.000 +es_ES30997.39154516011 +es_ES30 +4.000 +es_ESjCross - Contenedor Venta Privada NO Acumulable OI2223997.39128268011 +es_ESLContenedor Venta Privada no acumulableCDNN +es_ES&Sujetadores sin aro999.39072748013 +es_ES&Sujetadores sin aro +7.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN$310005292601731000529260483100052926031310005292669731000529268193100052926796310005292314631000529454833100052945872310005293541531000529350023100052935217310005293531631000529357293100052935705310005293560631000529350193100052935712A42862614A42862849A42862900A42862939A42863564A42868513A42866272A42867503A42864539158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42862758 +es_ES&Sujetadores sin aro999.39072748013 +es_ES&Sujetadores sin aro +7.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0015762 +es_ES4MAISONLEJABY IBERIA, S.L.U +es_ES8Sujetador patronado sin aros +es_ESSujetador patronado sin aros y sin foam, de encaje elástico. Esta línea es la reedición renovada de la famosa línea Miss Liberty, creada en 1972 por ML.A42862758345176056 LEJABY +es_ES LEJABY0015762 +es_ES4MAISONLEJABY IBERIA, S.L.U998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize +16442 +es_ES8Sujetador patronado sin aros +es_ES8Sujetador patronado sin aros +es_ESSujetador patronado sin aros y sin foam, de encaje elástico. Esta línea es la reedición renovada de la famosa línea Miss Liberty, creada en 1972 por ML. +calificacion1Acalificacion2Acalificacion3M5calificacion4VVcalificacion6WR00N47941709085 +es_ES85E +es_ESEspañol +Talla479431090C +es_ESCE +es_ESEspañol479431090C +es_ESC477062090EspañolCopapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-03-04T01:15:02.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-26T00:22:26.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-04T01:15:02.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a mano","name":[{"value":"Lavar a mano","locale":"es_ES"}],"external_identifier":"347780090","description":[{"value":"Lavar a mano","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Lavar a mano","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201301/25/___11516O1.png","size":"small"}],"description":[{"value":"Lavar a mano","locale":"es_ES"}],"identifier":"11516","name":[{"value":"LAVAR_A_MANO","locale":"es_ES"}],"external_identifier":"596937054"}}{"identifier":"No usar blanqueante","name":[{"value":"No usar blanqueante","locale":"es_ES"}],"external_identifier":"484894090","description":[{"value":"No usar blanqueante","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No necesita planchado","name":[{"value":"No necesita planchado","locale":"es_ES"}],"external_identifier":"392861090","description":[{"value":"No necesita planchado","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No lavar a máquina","name":[{"value":"No lavar a máquina","locale":"es_ES"}],"external_identifier":"349518090","description":[{"value":"No lavar a máquina","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa3kybygykw5doe ENTITY{"identifier":"Triángulo","name":[{"value":"Triángulo","locale":"es_ES"}],"external_identifier":"2655620090","description":[{"value":"Triángulo","locale":"es_ES"}],"type_lookup":"2505"}ONEa4aig6savkv75m STRING[{"locale":"es_ES","value":"Trasero"},{"locale":"pt_PT","value":"Traseiro"}]MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Sujetadores sin aro","name":[{"value":"Sujetadores sin aro","locale":"es_ES"}],"external_identifier":"12873137090","description":[{"value":"Sujetadores sin aro","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYagio3trrjaqhgg ENTITY{"identifier":"Fibras sintéticas","name":[{"value":"Fibras sintéticas","locale":"es_ES"}],"external_identifier":"22937672090","description":[{"value":"Fibras sintéticas","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sujetadores","name":[{"value":"Sujetadores","locale":"es_ES"}],"external_identifier":"2700632090","description":[{"value":"Sujetadores","locale":"es_ES"}],"type_lookup":"1599"}MANYaj3ufdvuwowrlw ENTITY{"identifier":"Sin aro","name":[{"value":"Sin aro","locale":"es_ES"}],"external_identifier":"2696269090","description":[{"value":"Sin aro","locale":"es_ES"}],"type_lookup":"1601"}ONEastcg34k65osv2 STRING[{"locale":"es_ES","value":"MISS LEJABY"},{"locale":"pt_PT","value":"MISS LEJABY"}]MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":72,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":28,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001525997070085(2022-03-04T01:15:02Z(2022-09-26T00:22:26Z(2022-03-04T01:15:02Z$001035813201072085001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore08508H5bc35f01-5e0f-43f0-832a-8e6d3a7965f8 DELETE<2023-09-02T17:28:15.095449421Z4dataloader-mongo-kafka-job62023-09-02T17:28:30.602028Z(mixer-gtin-agr-kfreeHc0bf5ce0-ee36-4117-8c93-778cf0bd854662023-09-02T17:32:11.180780Z,mixer-gtin-calc-pcsflmH9ac50aec-64c1-4965-8552-1efb87fb911162023-09-02T17:32:12.735263Z,mixer-gtin-calc-pcsflmHf54efb58-8a41-42a9-83ef-c36d52999e1062023-09-03T02:54:52.757438Z0mixer-product-calc-kfreeHa40b3cff-2fe5-4324-82c0-99df97e07a32<2024-01-19T11:18:24.969647172Z$mixer-xsell-mixtriHd06d9ce2-aa22-444c-823a-e10b3e48a94462024-01-19T11:18:25.030593Z4mixer-packing-units-mixtriH6cb23123-488f-456f-a88d-dc291c43107762024-01-19T11:18:27.039557Z.mixer-offer-badge-mixbiHd8e5754d-e181-421d-9884-ff076ba02b1f62024-01-19T11:21:27.407563Z.mixer-offer-badge-mixbiH512de564-a020-498f-ad2e-a6bb2a99d9588ǢcIVA02IGIC91 +3982800102023-04-24T18:08:55.692Z017738311457001309COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001017730939828070"2021-02-04T23:00Z4062059533324Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2021-02-25T23:23:16Z +es_ESRUNNING MUJER +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004062059533324$000001509878890070TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png2401788345587123471056 ADIDASmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/70/55/6/00001270556/00001270556634mM1011.jpg +es_ES adidas +es_ESCalzado999.53678013 +es_ESCalzado +7.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESZapatillas999.53819013 +es_ESZapatillas +2.000 +es_ESRunning999.53818013 +es_ESRunning 16.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESRunning999.14619892013 +es_ESRunning +2.000 +es_ES ZapatillasyBotas999.12473896013 +es_ES$Zapatillas y Botas +2.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESRunning999.53684013 +es_ESRunning 18.000 +es_ESCalzado999.53678013 +es_ESCalzado +7.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A387998125788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ES`Zapatillas de running de mujer Novamotion adidas +es_ESNo importa si todavía no has decidido cual va a ser la clase dirigida a la que te vas a apuntar hoy en el gimnasio, las zapatillas deportivas adidas Novamotion son idóneas para cualquier tipo de actividad física. Con este calzado de entrenamiento gozarás de una amortiguación única. Cuentan con una parte superior confeccionada en tejido de malla que favorecerá la transpiración y ventilación de tus pies para que continúes dándolo todo en cada ejercicio. La comodidad es uno de sus mejores atributos.A38799812123471056 ADIDAS +es_ES ADIDAS5788091600116392 +es_ESbSANCHEZ FERNANDEZ, FRANCISCO LOS PACOS_recargaNFTCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize FW3256 +es_ES`Zapatillas de running de mujer Novamotion adidas +es_ES`Zapatillas de running de mujer Novamotion adidas +es_ESNo importa si todavía no has decidido cual va a ser la clase dirigida a la que te vas a apuntar hoy en el gimnasio, las zapatillas deportivas adidas Novamotion son idóneas para cualquier tipo de actividad física. Con este calzado de entrenamiento gozarás de una amortiguación única. Cuentan con una parte superior confeccionada en tejido de malla que favorecerá la transpiración y ventilación de tus pies para que continúes dándolo todo en cada ejercicio. La comodidad es uno de sus mejores atributos. calificacion1Acalificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO0047930609040 y 2/3 +es_ES40 y 2/3E +es_ESEspañol4793990907 +es_ES718171618090Fabricante +Tallapler4twpwa2rdqphm44qlzhmwa2ypwe2kceprh5w3apaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-07-20T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-08-12T04:25:51.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-02-22T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa6b47f3ajuoqtm STRING[{"locale":"en_GB","value":"OrthoLite®"},{"locale":"fr_FR","value":"OrthoLite®"},{"locale":"es_ES","value":"OrthoLite®"}]ONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa7jpc7s7go77wi ENTITY{"identifier":"Textil","name":[{"value":"Textil","locale":"es_ES"}],"external_identifier":"392162090","description":[{"value":"Textil","locale":"es_ES"}],"type_lookup":"1633"}ONEa7urm4lkct2wni STRING[{"locale":"en_GB","value":"Cloudfoam"},{"locale":"fr_FR","value":"Cloudfoam"},{"locale":"es_ES","value":"Cloudfoam"}]ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Goma","name":[{"value":"Goma","locale":"es_ES"}],"external_identifier":"477871090","description":[{"value":"Goma","locale":"es_ES"}],"type_lookup":"1633"}MANYamzex7cmn57eei ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Malla","name":[{"value":"Malla","locale":"es_ES"}],"external_identifier":"10422274090","description":[{"value":"Malla","locale":"es_ES"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Running","name":[{"value":"Running","locale":"es_ES"}],"external_identifier":"373583090","description":[{"value":"Running","locale":"es_ES"}],"type_lookup":"1620"}ONEauur46vhpycka4 ENTITY{"identifier":"Deportivas mujer","name":[{"value":"Deportivas mujer","locale":"es_ES"}],"external_identifier":"373605090","description":[{"value":"Deportivas mujer","locale":"es_ES"}],"type_lookup":"1611"}MANYaxr5m2ljibnmui NUMBER2021Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001509878890070"2021-02-22T23:00ZDVD(2021-08-12T04:25:51Z"2021-07-20T22:00Z$001017730939828070001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore070H077ddd2e-0ff3-433c-9e3b-badc205e016f DELETE<2023-09-02T17:35:22.813429382Z4dataloader-mongo-kafka-job62023-09-02T17:39:33.522009Z(mixer-gtin-agr-kfreeHf5a5059a-bb5d-4be8-97f5-8d0cdb16ff8b62023-09-02T17:42:55.011386Z,mixer-gtin-calc-pcsflmH7b518ef1-e20b-47b0-aab5-3c759bd9a8fd62023-09-02T17:42:55.116503Z,mixer-gtin-calc-pcsflmH590e8768-8c69-400a-afc3-f2c6179a874862023-09-02T22:36:24.665639Z0mixer-product-calc-kfreeHa91da1db-c6b7-4203-8170-9bfeb3e3b383<2024-01-19T11:18:25.253134549Z$mixer-xsell-mixtriHfade5f0c-43f6-43e0-b290-67f7941b657262024-01-19T11:18:25.356599Z4mixer-packing-units-mixtriHd127cb92-a39f-49fe-91dc-25838496feca62024-01-19T11:18:27.051439Z.mixer-offer-badge-mixbiHe747a699-aa52-4b6d-a265-6d8e447fce5562024-01-19T11:21:27.408369Z.mixer-offer-badge-mixbiHa1e135ed-ca33-4882-b2e7-2226b0120ada8Ǣcn +$+ +}&IVA02IGIC91 +0069100102023-04-24T20:29:35.647Z025238627928001194COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001025219400691040"2020-09-29T22:00Z0194956870500 Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2021-03-29T10:42:35Z +es_ESCHANCLA UNISEX +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000194956870500$000001505508070040TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401777686141123744056NIKEmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201407/29/1248768132_2_.jpg +es_ESNike +es_ES^Deportes - Bonificación Especial Deportes PV22997.41837748011 +es_ESHBonificación Especial Deportes PV22N +es_ES>Deportes - Contenedor VVPP PV22997.42514389011 +es_ES(contenedor vvpp pv22N +es_ESDDeportes - Contenedor Rebajas PV22997.42771890011 +es_ES@contenedor rebajas deportes pv22N +es_ESVDeportes - Contenedor Deportes Rebaja final997.39703012011 +es_ES.Contenedor Rebaja finalN +es_ESPlaya - Piscina999.14598471013 +es_ESPlaya - Piscina 13.000 +es_ES ZapatillasyBotas999.12473891013 +es_ES$Zapatillas y Botas +2.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESDeportes997.42247120011 +es_ESDeportes 16.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESHBonificación especial Deportes OI21997.40172386011 +es_ESBESTSELLER WHOLESALE SPAIN,S.L.fCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA)  +es_ESLCamiseta de hombre gris de manga corta +es_ESCamiseta de manga corta en color gris con estampado de Guns N´Roses en el pecho. Tiene el cuello redondo.A379765433273009056ONLY&SONS +es_ESONLY&SONS6212151600502534 +es_ES>BESTSELLER WHOLESALE SPAIN,S.L.fCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize22018622 +es_ESLCamiseta de hombre gris de manga corta +es_ESLCamiseta de hombre gris de manga corta +es_ESCamiseta de manga corta en color gris con estampado de Guns N´Roses en el pecho. Tiene el cuello redondo. calificacion1Acalificacion2Acalificacion3M1calificacion4VVcalificacion5AAcalificacion611004792980904 +es_ES4E +es_ESEspañol479439090M +es_ESM18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02021-01-24T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-08-30T22:00:01.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}{"identifier":"Puede limpiarse en seco","name":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"external_identifier":"4197325090","description":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Redondo","name":[{"value":"Redondo","locale":"es_ES"}],"external_identifier":"485162090","description":[{"value":"Redondo","locale":"es_ES"}],"type_lookup":"1595"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001506991400003DVD(2021-08-30T22:00:01Z"2021-01-24T23:00Z$001012240016027003001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore003Hca3a9aca-80c6-410a-b8cd-8d2cb8b4a6ba DELETE<2023-09-02T17:32:21.181394608Z4dataloader-mongo-kafka-job62023-09-02T17:34:44.889566Z(mixer-gtin-agr-kfreeH92b10b89-14d8-4d03-a38b-21cb78e7284862023-09-02T17:46:35.304161Z,mixer-gtin-calc-pcsflmH46fe4ff9-1835-4a14-a347-be7322ceb5b662023-09-02T17:46:48.516014Z,mixer-gtin-calc-pcsflmH3294e08f-daca-43d8-a83f-5b40664b4e2b62023-09-02T19:28:41.439773Z0mixer-product-calc-kfreeH53738927-5ece-4140-b17f-48440d257ff7<2024-01-19T11:16:56.200372562Z$mixer-xsell-mixtriH2b4722b8-9f44-4620-81a0-8ef7c1146a6b62024-01-19T11:16:56.265794Z4mixer-packing-units-mixtriHffa77a6a-8ce3-43d1-8927-844a11d7d63a62024-01-19T11:18:27.114008Z.mixer-offer-badge-mixbiH5a0a5f70-6bee-42fd-ae48-4abc8ffc947362024-01-19T11:21:27.413725Z.mixer-offer-badge-mixbiHa017223b-b84d-4afd-82d6-5f3bdd51fbb28ǢcIVA02IGIC92 +0123100102023-03-15T02:56:46.454Z097542088393001825COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001097582501231 &includeAsWebNovelty +es_ESNovedadDVD0(2022-04-04T12:02:11Z +es_ES$GRAND THEFT AUTO V +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401835084490$0000000001528748222401835084490898507056TAKE TWO +es_ESTake-Two +es_ES Juegos999.36049424013 +es_ES Juegos +2.000 +es_ESXbox Series X999.36049418013 +es_ESXbox Series X 12.000 +es_ESVideojuegos999.51648013 +es_ESVideojuegosNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A434739010007235 +es_ESZAGENCIA MAKING OF PRODUCCIONESY SERVICIOS SLU +es_ES@Grand Theft Auto V Xbox Series XA434739019010281600007235 +es_ESZAGENCIA MAKING OF PRODUCCIONESY SERVICIOS SLUCALLE AUGUSTO FIGUEROA,PISO 3 D OF.6,17-28004 MADRID - MADRID (ESPAñA) 998.00072 +es_ESVideojuegos998.00071 +es_ESVideojuegos998 +es_ES@Jerarquía de Ficha de Productos366748NULO +es_ES@Grand Theft Auto V Xbox Series X 366748 +es_ES@Grand Theft Auto V Xbox Series X calificacion1Acalificacion2Ecalificacion3M5calificacion4VVcalificacion5Bcalificacion6LZ06Npler4twpwa2rdqp3dnlg7a5teleqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRINGRNO PUBLICAR REFERENCIA NO VALIDA 67424150ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-04-03T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-04-07T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa3g4hda6yppb2o NUMBER2ONEa6dlj4i6nnmir2 ENTITY{"identifier":"Blu-ray","name":[{"value":"Blu-ray","locale":"es_ES"}],"external_identifier":"353223090","description":[{"value":"Blu-ray","locale":"es_ES"}],"type_lookup":"147","glossary":{"term":[{"value":"BluRay Disc","locale":"es_ES"}],"media_objects":[],"description":[{"value":"El nombre del formato de disco óptico de nueva generación. Blu-ray Disc (BD) ofrece cinco veces más capacidad que los DVD tradicionales. Es decir, los usuarios descubrirán toda la grandeza original de las películas y la música al sumergirse de lleno en la experiencia de la alta definición. Disfrute de largometrajes con la mejor calidad de imagen de alta definición, un brillante sonido digital multicanal y gran cantidad de extras interactivos. Blu-ray Disc también se ha diseñado para almacenar contenido digital de alta definición como vídeo, sonido, imágenes, juegos, archivos de PC y todo lo que desee. PLAYSTATION 3 incluye una unidad BD-ROM Blu-ray Disc con la que podrá ver películas de alta definición 1080p y disfrutar de lo último en juegos.","locale":"es_ES"}],"identifier":"15821","name":[{"value":"BLURAY_DISC","locale":"es_ES"}],"external_identifier":"598446054"}}MANYaid666aq2taeu2 ENTITY {"identifier":"18+","name":[{"value":"18+","locale":"es_ES"}],"external_identifier":"351032090","description":[{"value":"18+","locale":"es_ES"}],"type_lookup":"468","glossary":{"term":[{"value":"PEGI +18","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20110607/___20333O2.jpg","size":"small"}],"description":[{"value":"Los juegos marcados con este PEGI sólo será adecuado para quienes tengan 18 o más años de edad","locale":"es_ES"}],"identifier":"20333","name":[{"value":"PEGI_+18","locale":"es_ES"}],"external_identifier":"598524054"}}MANYaiz26li3o6ckzi ENTITY{"identifier":"Acción","name":[{"value":"Acción","locale":"es_ES"}],"external_identifier":"350502090","description":[{"value":"Acción","locale":"es_ES"}],"type_lookup":"464"}{"identifier":"Lucha","name":[{"value":"Lucha","locale":"es_ES"}],"external_identifier":"353307090","description":[{"value":"Lucha","locale":"es_ES"}],"type_lookup":"464"}MANYak6mwwhyc7cx54 ENTITY{"identifier":"Castellano","name":[{"value":"Castellano","locale":"es_ES"}],"external_identifier":"347423090","description":[{"value":"Castellano","locale":"es_ES"}],"type_lookup":"157"}MANYapkjfs6k2ngtfm ENTITY{"identifier":"Xbox Series X","name":[{"value":"Xbox Series X","locale":"es_ES"}],"external_identifier":"36045543090","description":[{"value":"Xbox Series X","locale":"es_ES"}],"type_lookup":"462"}ONEaqxgozunrip354 ENTITY{"identifier":"Rockstar Games","name":[{"value":"Rockstar Games","locale":"es_ES"}],"external_identifier":"492104090","description":[{"value":"Rockstar Games","locale":"es_ES"}],"type_lookup":"460"}ONEaw27biqsglwa36 ENTITY{"identifier":"No","name":[{"value":"No","locale":"es_ES"}],"external_identifier":"347406090","description":[{"value":"No","locale":"es_ES"}],"type_lookup":"144"}MANYawuzmljsrugyrq ENTITY{"identifier":"Inglés","name":[{"value":"Inglés","locale":"es_ES"}],"external_identifier":"347433090","description":[{"value":"Inglés","locale":"es_ES"}],"type_lookup":"157"}ONEaxksbkyx3rdtq4 ENTITY{"identifier":"Juego exclusivo","name":[{"value":"Juego exclusivo","locale":"es_ES"}],"external_identifier":"3204628090","description":[{"value":"Juego exclusivo","locale":"es_ES"}],"type_lookup":"3006"}ONEaxmtn5gzfedy5e ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}ONEay2d2eqkhvtvqg ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}Videojuegos_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000152874822"2022-04-07T22:00Z"2022-04-03T22:00Z$001097582501231 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H17c51967-0222-4636-87fb-02d2de093875 DELETE<2023-09-02T17:21:55.302864991Z4dataloader-mongo-kafka-job62023-09-02T17:22:04.545632Z(mixer-gtin-agr-kfreeHe2fa67d8-70a6-4267-8b0b-8611350793ef62023-09-02T17:22:15.037194Z,mixer-gtin-calc-pcsflmH21dc46cf-8335-4bda-a103-94a715ed189362023-09-02T17:22:20.621336Z,mixer-gtin-calc-pcsflmH353027e9-10ed-4b59-b49d-89935551247e62023-09-03T02:48:54.881858Z0mixer-product-calc-kfreeH63919973-05ea-406d-bb3e-692dfa0e7f3d<2024-01-19T11:18:26.308649256Z$mixer-xsell-mixtriH39af06f8-04a1-4079-9ad0-2a7791eaa04662024-01-19T11:18:26.406536Z4mixer-packing-units-mixtriH8897da9b-c2c0-4f82-8111-1f49f98d359062024-01-19T11:18:27.534589Z.mixer-offer-badge-mixbiH42c84877-474e-4497-a88d-87d718e2740362024-01-19T11:21:27.415079Z.mixer-offer-badge-mixbiH96c8bff4-a9b2-4cad-ac21-5611c6ea74bb8ǢcLoffer(A40781175).publish_ends_extendedIVA02IGIC91 +00334001004841252186001500COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001004850000334058&includeAsWebNovelty +es_ESNovedadDVD Grises +es_ES Grises Grises +es_ES GrisesGris +es_ESGris344777090 +es_ESGris5996500544940 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png +es_ESCOLOR_GRIS +es_ESColor GrisGris +es_ESGris0(2022-01-11T13:09:42Z +es_ES*CAZADORA LIGERA TECNI155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401808470923$000001517212010058TRADICIONAL +es_ESCOLOR_GRIS +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png2401808470923129614056 DUSTINmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/2/00001269352/00001269352440mM1011.jpg +es_ES Dustin + +es_ES"Hombre y Equipaje997.38864709011 +es_ES"Hombre y Equipaje +9.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ES(Moda_Hombre_BÁSICOS997.18082380011 +es_ESBasicos HombreCD +es_ESCazadoras999.39072571013 +es_ESCazadoras 12.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ES,Cross - Contenedor 8DO997.41837795011 +es_ESContenedor 8DOCD +es_ESRopa997.41964119011 +es_ESRopa +4.000 +es_ESModa Hombre997.41875779011 +es_ESModa Hombre 31.000 +es_ES,Cross - Contenedor 8DO997.41837795011 +es_ESContenedor 8DOCDNN001004981612940001004225500737155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40781175 +es_ESCazadoras999.39072571013 +es_ESCazadoras 12.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN5934231600942649 +es_ES"NCR ESPAÑA, S.L.CALLE COMANDANTE AZCARRAGA 3,-S-N-28016 MADRID - MADRID (ESPAñA)  +es_ESpCazadora Essential de hombre Essential con dos bolsillos +es_ESCazadora Essential básica con dos bolsillos delanteros, cuello alto y cierre de cremallera.A40781175129614056 DUSTIN +es_ES DUSTIN5486731600942649 +es_ES*SAMSUNG S.P.A LIMITEDCALLE UNIT C 20/F, FULL WIN COMMERCI,..- KOWLOON - (HONG KONG) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize22D2901 +es_ESpCazadora Essential de hombre Essential con dos bolsillos +es_ESpCazadora Essential de hombre Essential con dos bolsillos +es_ESCazadora Essential básica con dos bolsillos delanteros, cuello alto y cierre de cremallera. calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5NScalificacion6P00N47938209058 +es_ES58E +es_ESEspañol47938209058 +es_ES58477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-06T01:04:09.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-07T01:04:09.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-02-14T05:56:49.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}ONEa4aig6savkv75m STRING[{"locale":"es_ES","value":"Cremallera"},{"locale":"pt_PT","value":"Fecho de correr"},{"locale":"en_GB","value":"Zip"},{"locale":"fr_FR","value":"Fermeture éclair"}]MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Sport","name":[{"value":"Sport","locale":"es_ES"}],"external_identifier":"347623090","description":[{"value":"Sport","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Cazadoras","name":[{"value":"Cazadoras","locale":"es_ES"}],"external_identifier":"485264090","description":[{"value":"Cazadoras","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517212010058(2022-02-14T05:56:49Z(2022-09-07T01:04:09Z(2022-09-06T01:04:09Z$001004850000334058001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore058H4e250f95-9172-4a1b-86e6-7b30fcfc596e DELETE<2023-09-02T17:19:40.318452831Z4dataloader-mongo-kafka-job62023-09-02T17:19:52.153929Z(mixer-gtin-agr-kfreeHc5c77ede-74d3-4365-91e9-ef6f10ae919a62023-09-02T17:20:08.216199Z,mixer-gtin-calc-pcsflmH5128bd4e-e18b-44d8-ab4b-7cc08d12a10162023-09-02T17:20:12.302568Z,mixer-gtin-calc-pcsflmHc6417734-f87b-4339-9d93-3a50ccc1fd1e62023-09-03T02:36:05.577091Z0mixer-product-calc-kfreeHdb7c911c-c8b8-4848-a880-e715141600a8<2024-01-19T11:18:00.201135417Z$mixer-xsell-mixtriH7e6a43d2-3377-4218-9257-ec25f3da93ad62024-01-19T11:18:00.765914Z4mixer-packing-units-mixtriH2decf1d4-b6ab-448b-9355-cd514df9fd2162024-01-19T11:18:27.353237Z.mixer-offer-badge-mixbiHdb1eeb72-3882-484c-8813-cf63063256af62024-01-19T11:21:27.416074Z.mixer-offer-badge-mixbiH8d14f357-c4d7-4db3-ab85-6abc28fa962d8ǢcLoffer(A43248294).publish_ends_extendedIVA02IGIC91 +08230001010043630216001224COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001010022408230048&includeAsWebNovelty +es_ESNovedadDVDNatural +es_ESNaturalNatural +es_ESNatural +Beige +es_ES +Beige344754090 +es_ES +Beige599054054 +25619 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100629/___25619O1.png +es_ESCOLOR_BEIGE +es_ESColor Beige +Beige +es_ES +Beige0(2022-09-08T13:33:46Z +es_ESCHAQUETA HERZOG26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401832909765$000001527826770048TRADICIONAL +es_ESCOLOR_BEIGE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100629/___25619O1.png24018329097653120224056SCHNEIDERS +es_ESSchneiders +es_ESChaquetas999.14598528013 +es_ESChaquetas +6.000 +es_ESRopa deportiva999.12473890013 +es_ESRopa deportiva +1.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESDeportes997.44463815011 +es_ESDeportes 17.000 +es_ESHCross - Contenedor 2022 Cyber Monday997.44305671011 +es_ESContenedor CMCDN +es_ESDDeportes - Contenedor rebajas OI22997.44869638011 +es_ESDDeportes - Contenedor rebajas OI22N +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ES`Deportes - Contenedor VVPP OI22 mercancía al 30997.44550101011 +es_ESHContenedor VVPP OI22 mercancia al 30N +es_ESRopa997.41016311011 +es_ESRopa +1.000 +es_ESCaza997.40963460011 +es_ESCaza 19.000 +es_ESDeportes997.40925048011 +es_ESDeportes 11.000 +es_ES$Cross - Feliz 2023997.40925036011 +es_ESFeliz 2023CDNNN +es_ESRopa deportiva997.40963448011 +es_ESRopa deportiva +3.000 +es_ESDeportes997.40925048011 +es_ESDeportes 11.000 +es_ES$Cross - Feliz 2023997.40925036011 +es_ESFeliz 2023CDNN +es_ESRopa999.53816013 +es_ESRopa +2.000 +es_ESCaza999.53805013 +es_ESCaza 29.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESLDeportes - Contenedor adelanto rebajas997.45098029011 +es_ESLDeportes - Contenedor adelanto rebajasN26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43248294 +es_ESChaquetas999.14598528013 +es_ESChaquetas +6.000 +es_ESRopa deportiva999.12473890013 +es_ESRopa deportiva +1.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN5943851600963405 +es_ES*COBO RODRIGUEZ, ANGELbCALLE JAPON,21-28923 ALCORCON - MADRID (ESPAñA)  +es_ESHChaqueta de hombre Herzog Schneiders +es_ESDeportivo en escena con un diseño de chaqueta de campo. Cuatro bolsillos de parche con solapa y una tira de cierre abotonada con cremallera bidireccional oculta, así como costuras llamativas, enfatizan esta deportividad masculina. Un cálido forro acolchado y un cuello de piel de cordero extraíble destacan con carácter junto con las propiedades naturales del tejido loden. Esta tela ha sido fabricada por la empresa Mehler utilizando la artesanía tradicional durante más de 350 años.A432482943120224056SCHNEIDERS +es_ESSCHNEIDERS5943851600963405 +es_ES*COBO RODRIGUEZ, ANGELbCALLE JAPON,21-28923 ALCORCON - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize22 236 0042 +es_ESHChaqueta de hombre Herzog Schneiders +es_ESHChaqueta de hombre Herzog Schneiders +es_ESDeportivo en escena con un diseño de chaqueta de campo. Cuatro bolsillos de parche con solapa y una tira de cierre abotonada con cremallera bidireccional oculta, así como costuras llamativas, enfatizan esta deportividad masculina. Un cálido forro acolchado y un cuello de piel de cordero extraíble destacan con carácter junto con las propiedades naturales del tejido loden. Esta tela ha sido fabricada por la empresa Mehler utilizando la artesanía tradicional durante más de 350 años. +calificacion1Acalificacion2Acalificacion4VVcalificacion5AHcalificacion6BA00N47935009048 +es_ES48E +es_ESEspañol47935009048 +es_ES48477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-06T13:38:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-07T13:38:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-09-06T13:38:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Chaquetas","name":[{"value":"Chaquetas","locale":"es_ES"}],"external_identifier":"347705090","description":[{"value":"Chaquetas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Chaquetas","name":[{"value":"Chaquetas","locale":"es_ES"}],"external_identifier":"347862090","description":[{"value":"Chaquetas","locale":"es_ES"}],"type_lookup":"1599"}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001527826770048"2022-09-06T13:38Z"2022-09-07T13:38Z"2022-09-06T13:38Z$001010022408230048001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore048Hecded04a-84a4-4b49-81af-dc3b15afc8d1 DELETE<2023-09-02T17:19:43.332692722Z4dataloader-mongo-kafka-job62023-09-02T17:19:57.699946Z(mixer-gtin-agr-kfreeHd762573b-e0f1-4873-b1f3-3f4200b05c3462023-09-02T17:20:18.209034Z,mixer-gtin-calc-pcsflmH021fea56-b089-41a6-b38f-4b28169588dc62023-09-02T17:20:23.409226Z,mixer-gtin-calc-pcsflmHe9bf8503-6560-4957-9825-c6753841302462023-09-03T02:36:10.947370Z0mixer-product-calc-kfreeH73409209-25da-48f6-9677-9fc5e5822e6e<2024-01-19T11:18:00.209066599Z$mixer-xsell-mixtriHbd8eb1f6-9c2f-45da-b16a-755a24f9d47862024-01-19T11:18:00.768557Z4mixer-packing-units-mixtriH03347290-45fe-42bb-907b-5d0cd0b5524262024-01-19T11:18:27.354086Z.mixer-offer-badge-mixbiH8c27d0ab-eb24-44e3-8b68-29eef11a109462024-01-19T11:21:27.417627Z.mixer-offer-badge-mixbiH6058b595-c0e8-4bc8-bd8e-df8469371ecd8ǢcIVA02IGIC91 +1212400102023-02-12T04:41:18.469Z034731631896001551COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001034755112124004&includeAsWebNovelty +es_ESNovedadDVD"2018-03-19T23:00Z7322625929607 Verdes +es_ES Verdes Verdes +es_ES VerdesVerde oscuro +es_ESVerde oscuro347659090 +es_ESVerde oscuro596810054 +10542 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100716/___10542O1.png +es_ES$COLOR_VERDE_OSCURO +es_ES$Color Verde OscuroVerde oscuro +es_ESVerde oscuro0(2019-04-02T15:30:04Z +es_ESGANT +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0007322625929607$000001464129770004TRADICIONAL +es_ES$COLOR_VERDE_OSCURO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100716/___10542O1.png2401676278027130391056GANTmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/0/00001269350/00001269350465mM1011.jpg +es_ESGant +es_ES +Polos999.39072576013 +es_ES +Polos 11.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ES +Polos999.8482544013 +es_ES +Polos +2.000 +es_ES2014 Hombre999.2680805013 +es_ES Hombre +2.000 +es_ESModa999.53895013 +es_ESModaNNN +es_ES(Moda_Hombre_BÁSICOS997.18082380011 +es_ESBasicos HombreCD7325702191874732570219186773257021918297325702191812501212325118950121232511345012123251141501212325120250121232512405012123251233A24233721A28235875 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A260259455824631600158006 +es_ESFDISTRIBUIDORA ALIMENT GIROMAR, S.A.CALLE NELSON MANDELA.9.P.I.RUBIESAS,..-35214 CRUCE DE MELENARA-TELDE - LAS PALMAS (ESPAñA)  +es_ESnPolo piqué de hombre Gant classic verde de manga corta +es_ESPolo básico de piqué y manga corta, de color verde oscuro. Lleva el logo de la firma bordado en el pecho.A26025945130391056GANT +es_ESGANT5824631600158006 +es_ESFDISTRIBUIDORA ALIMENT GIROMAR, S.A.CALLE NELSON MANDELA.9.P.I.RUBIESAS,..-35214 CRUCE DE MELENARA-TELDE - LAS PALMAS (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize2201 +es_ESnPolo piqué de hombre Gant classic verde de manga corta +es_ESnPolo piqué de hombre Gant classic verde de manga corta +es_ESPolo básico de piqué y manga corta, de color verde oscuro. Lleva el logo de la firma bordado en el pecho. +calificacion1Acalificacion2Acalificacion3RIcalificacion4VVcalificacion5CR0047936909052 +es_ES52E +es_ESEspañol479437090L +es_ESL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02018-06-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02019-06-15T22:00:01.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02019-03-30T23:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYa5r36nvug7ald6 ENTITY{"identifier":"Classic","name":[{"value":"Classic","locale":"es_ES"}],"external_identifier":"12970401090","description":[{"value":"Classic","locale":"es_ES"}],"type_lookup":"1594"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Polos","name":[{"value":"Polos","locale":"es_ES"}],"external_identifier":"372101090","description":[{"value":"Polos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2019Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001464129770004"2019-03-30T23:00Z(2019-06-15T22:00:01Z(2018-06-15T22:00:01Z$001034755112124004001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore004H79650b8a-9c64-4a10-8b21-3dd85f5c45d8 DELETE<2023-09-02T17:12:19.615641542Z4dataloader-mongo-kafka-job62023-09-02T17:12:30.244561Z(mixer-gtin-agr-kfreeHdf1d0d6e-3f29-45cc-87d0-3336d732c7f762023-09-02T17:12:47.611880Z,mixer-gtin-calc-pcsflmH3fd41247-22d5-4de9-bac2-0c6bf009986262023-09-02T17:12:48.505055Z,mixer-gtin-calc-pcsflmH75a76ea2-578d-445b-a462-c49cf31025e462023-09-03T02:40:37.747996Z0mixer-product-calc-kfreeHbac35d0e-1823-4b95-aa26-782049374068<2024-01-19T11:18:00.562545665Z$mixer-xsell-mixtriH438caeed-bf14-438d-bf4d-826ba62cf06962024-01-19T11:18:01.008505Z4mixer-packing-units-mixtriH41016eee-4d27-4688-86d3-b4e23448635c62024-01-19T11:18:27.825616Z.mixer-offer-badge-mixbiH1a3f2138-6a18-485f-a55c-13d5173428ce62024-01-19T11:21:27.419421Z.mixer-offer-badge-mixbiH3baa4e38-f836-4b87-8af4-6c6e79b3a9d38ǢcIVA02IGIC91 +0574500102023-02-03T18:22:29.300Z053027306241001551COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001053055105745005&includeAsWebNovelty +es_ESNovedadDVD"2018-06-13T22:00Z8055185714015 Grises +es_ES Grises Grises +es_ES GrisesGris oscuro +es_ESGris oscuro347603090 +es_ESGris Oscuro5996810545055 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___5055O2.png +es_ES"COLOR_GRIS_OSCURO +es_ES"Color Gris OscuroGris oscuro +es_ESGris oscuro0(2018-09-21T23:01:22Z +es_ESPOLO +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008055185714015$000001467934820005TRADICIONAL +es_ES"COLOR_GRIS_OSCURO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___5055O2.png2401685528021164073056EMPORIO ARMANImarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/8/00001269358/00001269358550mM1011.jpg +es_ESEmporio Armani +es_ES +Polos999.39072576013 +es_ES +Polos 11.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ES +Polos999.8482544013 +es_ES +Polos +2.000 +es_ES2014 Hombre999.2680805013 +es_ES Hombre +2.000 +es_ESModa999.53895013 +es_ESModaNNN 805452477411680545247740938054524774109805452477408680545247732495012123116020A26875353A25582388 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A268751530901936 +es_ES$GIORGIO ARMANI SPA +es_ESDPolo de hombre gris de manga corta +es_ESPolo de manga corta, de color gris oscuro microestampado y el cuello con detalle. Lleva el logo de la firma bordado.A26875153164073056EMPORIO ARMANI +es_ESEMPORIO ARMANI8832211600901936 +es_ES$GIORGIO ARMANI SPAfCALLE VIA BORGONUOVO 11,.-20121 MILANO - (ITALIA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize6Z1FP9-1JTWZ +es_ESDPolo de hombre gris de manga corta +es_ESDPolo de hombre gris de manga corta +es_ESPolo de manga corta, de color gris oscuro microestampado y el cuello con detalle. Lleva el logo de la firma bordado. calificacion1Acalificacion2Acalificacion3RIcalificacion4VVcalificacion5Z1calificacion6I0047936909052 +es_ES52E +es_ESEspañol479445090XL +es_ESXL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02018-06-15T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02019-06-15T22:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02018-09-18T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Microestampado","name":[{"value":"Microestampado","locale":"es_ES"}],"external_identifier":"25521451090","description":[{"value":"Microestampado","locale":"es_ES"}],"type_lookup":"2504"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Polos","name":[{"value":"Polos","locale":"es_ES"}],"external_identifier":"372101090","description":[{"value":"Polos","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Gris","color_description":[{"value":"Gris","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Gris","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png","size":"small"}],"description":[{"value":"Gris","locale":"es_ES"}],"identifier":"4940","name":[{"value":"COLOR_GRIS","locale":"es_ES"}],"external_identifier":"599650054"},"identifier":"Gris","name":[{"value":"Gris","locale":"es_ES"}],"external_identifier":"344777090"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2018Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001467934820005"2018-09-18T22:00Z(2019-06-15T22:00:01Z(2018-06-15T22:00:01Z$001053055105745005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H4912e504-d6ad-4cec-b7b2-0bab9950013f DELETE<2023-09-02T17:10:15.068230403Z4dataloader-mongo-kafka-job62023-09-02T17:10:29.094191Z(mixer-gtin-agr-kfreeH93760b71-1235-49ee-b1a5-adbee4ec085962023-09-02T17:11:06.612172Z,mixer-gtin-calc-pcsflmH7df86f1c-a197-40f5-af6e-6caf0468e74362023-09-02T17:11:13.104287Z,mixer-gtin-calc-pcsflmH0913f02c-2350-44fd-9252-7d3e07c0dcbb62023-09-03T02:39:04.188040Z0mixer-product-calc-kfreeH5fe6a0f9-e115-449d-a553-dc790daab9a1<2024-01-19T11:17:57.368647853Z$mixer-xsell-mixtriHece404cb-69e6-4bbe-b94e-95e5bb57b9f662024-01-19T11:18:01.064019Z4mixer-packing-units-mixtriHcc63646d-beb6-4b1f-9fe8-21a98fa24f9562024-01-19T11:18:27.828964Z.mixer-offer-badge-mixbiHcf1567e6-9a87-4f5c-94d4-ac91e9744be362024-01-19T11:21:27.420132Z.mixer-offer-badge-mixbiHdb06a947-f5af-46e5-9772-d1e94f5a4d038Ǣcn +$+ +}&Loffer(A41246311).publish_ends_extendedIVA02IGIC91 +24082001011040322004001301COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001011030124082002&includeAsWebNovelty +es_ESNovedadDVD +es_ESLos envases o productos que contienen este sello garantizan su biodegrabalidad completa conforme a unos requerimientos específicos31954260090 +es_ESLos envases o productos que contienen este sello garantizan su biodegrabalidad completa conforme a unos requerimientos específicos38531246054 +21903 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/21903_1_.png +es_ESOK_COMPOST +es_ESOk Compost +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/21903_1_.png004 +es_ESOk Compost8SUSTAINABILITY_MANUFACTURING +es_ESEste producto está fabricado a partir de fibras de algodón obtenidas en un proceso de reciclaje de prendas y productos textiles ya usados. Estas fibras de algodón reciclado se mezclan con otros tipos de fibras, como el algodón orgánico, para mejorar su resistencia y crear nuevos productos de manera respetuosa con el medio ambiente.31820065090 +es_ESEste producto está fabricado a partir de fibras de algodón obtenidas en un proceso de reciclaje de prendas y productos textiles ya usados. Estas fibras de algodón reciclado se mezclan con otros tipos de fibras, como el algodón orgánico, para mejorar su resistencia y crear nuevos productos de manera respetuosa con el medio ambiente.31845108054 +31812 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202103/04/31812_2_.png +es_ES"ALGODON_RECICLADO +es_ES$Algodón Reciclado +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/202103/04/31812_2_.png015 +es_ES$Algodón Reciclado:SUSTAINABILITY_CLOSING_CIRCLE"2021-09-26T22:00Z8057163285289Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2021-09-28T06:05:08Z +es_ES,TANGA LISO DE ALGODÓN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008057163285289$000001518891630002TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png2401812649131164073056EMPORIO ARMANImarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/8/00001269358/00001269358550mM1011.jpg +es_ESEmporio Armani +es_ES Tangas999.39072764013 +es_ES Tangas +2.000 +es_ES Bragas999.39072755013 +es_ES Bragas 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41246311 +es_ES Tangas999.39072764013 +es_ES Tangas +2.000 +es_ES Bragas999.39072755013 +es_ES Bragas 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0906018 +es_ES*GIORGIO ARMANI S.P.A. +es_ES,Tanga liso de algodón +es_ESTanga liso en blalnco. Algodón orgánico para Basic Cotton, otra línea que se enmarca en el Proyecto de Sostenibilidad de Armani. Un diseño contemporáneo y minimalista, combinado con el nuevo logo adornado con tono oro rosa, enfatiza la calidad superior de la tela utilizada, lo que garantiza una extrema comodidad y un ajuste impecable.A41246311164073056 ARMANI +es_ES ARMANI13918701600906018 +es_ES*GIORGIO ARMANI S.P.A.bCALLE VIA BORGONUOVO,11-20121 MILANO - (ITALIA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize1624682R223 +es_ES,Tanga liso de algodón +es_ES,Tanga liso de algodón +es_ESTanga liso en blalnco. Algodón orgánico para Basic Cotton, otra línea que se enmarca en el Proyecto de Sostenibilidad de Armani. Un diseño contemporáneo y minimalista, combinado con el nuevo logo adornado con tono oro rosa, enfatiza la calidad superior de la tela utilizada, lo que garantiza una extrema comodidad y un ajuste impecable. calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AHcalificacion6FI00N479443090S +es_ESSE +es_ESEspañol479443090S +es_ESS477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-27T00:58:28.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-28T00:58:28.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-27T04:42:43.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar máximo 30º C","name":[{"value":"Lavar máximo 30º C","locale":"es_ES"}],"external_identifier":"21449008090","description":[{"value":"Lavar máximo 30º C","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}{"identifier":"No planchar","name":[{"value":"No planchar","locale":"es_ES"}],"external_identifier":"350554090","description":[{"value":"No planchar","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No Planchar","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___840O1.png","size":"small"}],"description":[{"value":"No Planchar","locale":"es_ES"}],"identifier":"840","name":[{"value":"NO_PLANCHAR","locale":"es_ES"}],"external_identifier":"600047054"}} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Continuidad","name":[{"value":"Continuidad","locale":"es_ES"}],"external_identifier":"2696215090","description":[{"value":"Continuidad","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Tangas","name":[{"value":"Tangas","locale":"es_ES"}],"external_identifier":"347796090","description":[{"value":"Tangas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYagio3trrjaqhgg ENTITY{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Bragas","name":[{"value":"Bragas","locale":"es_ES"}],"external_identifier":"2700627090","description":[{"value":"Bragas","locale":"es_ES"}],"type_lookup":"1599"}ONEaj74fe6v7bf7eg ENTITY{"identifier":"No","name":[{"value":"No","locale":"es_ES"}],"external_identifier":"347406090","description":[{"value":"No","locale":"es_ES"}],"type_lookup":"144"}ONEarte4uoeu4rkhe ENTITY{"identifier":"Tanga","name":[{"value":"Tanga","locale":"es_ES"}],"external_identifier":"2655625090","description":[{"value":"Tanga","locale":"es_ES"}],"type_lookup":"2506"}ONEastcg34k65osv2 STRING[{"locale":"en_GB","value":"Basic Cotton"},{"locale":"fr_FR","value":"Basic Cotton"},{"locale":"pt_PT","value":"Basic Cotton"},{"locale":"es_ES","value":"Basic Cotton"}]MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":95,"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"},"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"}},{"adbyfb4jfvuv5k":5,"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"},"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"}}]}]}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518891630002(2022-03-27T04:42:43Z(2022-09-28T00:58:28Z(2022-09-27T00:58:28Z$001011030124082002001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore002H007553b7-663c-4d89-9b9e-b931f3d4dc36 DELETE<2023-09-02T17:27:05.276701837Z4dataloader-mongo-kafka-job62023-09-02T17:27:11.481239Z(mixer-gtin-agr-kfreeHe1f2b0ee-195e-4103-9c74-57bea3261f0362023-09-02T17:29:34.904748Z,mixer-gtin-calc-pcsflmHb973413e-71a0-4345-b6b3-4426a940b38e62023-09-02T17:29:38.509656Z,mixer-gtin-calc-pcsflmH260c200e-f349-478f-beeb-815a18c786f862023-09-03T02:58:04.590705Z0mixer-product-calc-kfreeHc18d94b3-dd7f-429c-9386-034180ad355e<2024-01-19T11:18:24.650970324Z$mixer-xsell-mixtriHf61a99c2-3111-4396-a363-0051537e689762024-01-19T11:18:24.699208Z4mixer-packing-units-mixtriH970910ed-6fff-495d-a44c-aeb8cef106b662024-01-19T11:18:27.847058Z.mixer-offer-badge-mixbiH74d97bd0-66c0-42c8-87b3-f0ed5b064ba862024-01-19T11:21:27.420906Z.mixer-offer-badge-mixbiH6731db03-2a10-4629-a617-441cf072f4d68ǢcLoffer(A40458379).publish_ends_extendedIVA02IGIC91 +01337001067241087392001325COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001067232501337005 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa +es_ESRosa347700090 +es_ESRosa5985060542019 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png +es_ESCOLOR_ROSA +es_ESColor RosaRosa +es_ESRosa0(2021-12-23T16:17:32Z +es_ES(CAMISETA ML LICENCIA156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401805185905$000001516029720005TRADICIONAL +es_ESCOLOR_ROSA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png240180518590539212703056(KIDS EL CORTE INGLES +es_ES*Kids El Corte Inglés +es_ESCamisetas999.39073142013 +es_ESCamisetas +3.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN +es_ESInfantil997.38839707011 +es_ESInfantil +3.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESModa Infantil997.41875781011 +es_ESModa Infantil 33.000 +es_ES,Cross - Contenedor 8DO997.41837795011 +es_ESContenedor 8DOCDN +es_ESModa Infantil997.42153203011 +es_ESModa Infantil +8.000 +es_ES18 abril997.41749958011 +es_ES18 abril 11.000 +es_ES>Cross - Contenedor Noches Flash997.40995448011 +es_ES.Contenedor Noches FlashCDNNZ240180390968824018039097012401803909695240180390963324018039097182401803909596240180390966424018039096712401803909657240180391006624018039099542401803910004240180391005924018039099782401803910073240180391002824018039099852401803910042240180518504224018051849842401805185028240180518488524018051850662401805185080240180518505924018051850732401805185004240180457768824018045776952401804577671240180457770124018045776642401804577640240180457761924018045777182401804577657240180405978824018040597192401804059696240180405972624018040597642401804059740240180405973324018040598012401804059825 +A40334542A40334580A40458311A40401698A40349009156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40458379 +es_ESCamisetas999.39073142013 +es_ESCamisetas +3.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN0906729 +es_ES4UNIVERSAL MUSIC SPAIN S.L. +es_ES@Camiseta de niña Rolling Stones +es_ESpCamiseta manga larga Rolling Stones en color rosa claro.A4045837939212703056UNIVERSAL MUSIC +es_ESUNIVERSAL MUSIC14502341600906729 +es_ES4UNIVERSAL MUSIC SPAIN S.L.NCALLE TORRELAGUNA,64- CHINA - (CHINA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize22T6193 +es_ES@Camiseta de niña Rolling Stones +es_ES@Camiseta de niña Rolling Stones +es_ESpCamiseta manga larga Rolling Stones en color rosa claro. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5VV00N4793610905 Años +es_ES5 AñosE +es_ESEspañol194624250904-5 +es_ES4-518171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING(Fuerzo Rebajas 80822ONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-16T04:42:42.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-17T04:42:42.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-05-02T22:00:01.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"351059090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niña","name":[{"value":"Niña","locale":"es_ES"}],"external_identifier":"357131090","description":[{"value":"Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001516029720005(2022-05-02T22:00:01Z(2022-09-17T04:42:42Z(2022-09-16T04:42:42Z$001067232501337005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H0ffed89b-17a4-4bdf-a765-e25e95270fb4 DELETE<2023-09-02T17:22:52.883573848Z4dataloader-mongo-kafka-job62023-09-02T17:23:03.895158Z(mixer-gtin-agr-kfreeH8082f989-256d-4d0b-9a99-ce13cd0a472862023-09-02T17:23:11.715034Z,mixer-gtin-calc-pcsflmHe13dc3e2-5bb9-462b-9f9e-52956b3ed25362023-09-02T17:23:15.413045Z,mixer-gtin-calc-pcsflmH93da2599-d10a-4e54-8986-20e0e52025f562023-09-03T02:49:55.075051Z0mixer-product-calc-kfreeH21d23299-d319-4568-88ff-1ec190456367<2024-01-19T11:18:26.749052273Z$mixer-xsell-mixtriH21f92469-1c8d-4869-9d62-2b1d0de061aa62024-01-19T11:18:26.789370Z4mixer-packing-units-mixtriH6a902d6a-737b-4bdb-9079-a77b85f9f3cb62024-01-19T11:18:27.541006Z.mixer-offer-badge-mixbiH115486cd-34d9-4a45-b12a-35f33d2c26af62024-01-19T11:21:27.423915Z.mixer-offer-badge-mixbiHc1cd0345-f337-42a0-a294-2810ba0ee6208ǢcLoffer(A15580754).publish_ends_extendedIVA08IGIC90"2022-09-24T22:00Z +5585900102558584092001160LIBROS DE TEXTO +es_ESLIBROS DE TEXTOCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001025516055859 "2018-02-08T23:00Z97884985537890(2015-06-06T00:48:57Z +es_ES*6LH KOAD 3 EUSKARA B1 +es_ES Libros274977090 Libros395ML +es_ESml +0.0009788498553789$0000000001080188432401558296248146635056SM +es_ESSM +es_ESPrimaria 6999.1149227013 +es_ESSexto Primaria 15.000 +es_ESLibros de Texto999.906419013 +es_ESLibros de Texto 32.000 +es_ES Libros999.54302013 +es_ES LibrosNNN1 +es_ES Libros274977090 Libros395A15580754 +es_ESPrimaria 6999.1149227013 +es_ESSexto Primaria 15.000 +es_ESLibros de Texto999.906419013 +es_ESLibros de Texto 32.000 +es_ES Libros999.54302013 +es_ES LibrosNNN5574881602020693 +es_ESSM ,- - ()  +es_ES|Koadernoa euskara. Lehen Hezkuntza 6, 3 Hiruhilekoa. Bizigarri +es_ESEuskaran, ikasleei eraginkortasunez komunikatzen lagunduko dieten trebetasun linguistikoak garatzea du helburu Bizigarri proiektuak.Euskal hizkuntza eta literatura, komunikazioaren ikuspegitik, eta dagokion kultura-errealitatean kokatuta.Komunikazio-egoerak oinarri hartuta proposatutako jarduerak, ikasliburuko edukiak finkatzeko.A15580754146635056SM +es_ESSM5781081600109389 +es_ESHMERCAFRIO SERVICIOS DE MANTENIMIENT.CALLE ROMERO 11 N-F2 POL.EMPRESARIUM,.-50720 LA CARTUJA - ZARAGOZA (ESPAñA) 998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de Productos9788498553789 +es_ES|Koadernoa euskara. Lehen Hezkuntza 6, 3 Hiruhilekoa. Bizigarri +es_ES|Koadernoa euskara. Lehen Hezkuntza 6, 3 Hiruhilekoa. Bizigarri +es_ESEuskaran, ikasleei eraginkortasunez komunikatzen lagunduko dieten trebetasun linguistikoak garatzea du helburu Bizigarri proiektuak.Euskal hizkuntza eta literatura, komunikazioaren ikuspegitik, eta dagokion kultura-errealitatean kokatuta.Komunikazio-egoerak oinarri hartuta proposatutako jarduerak, ikasliburuko edukiak finkatzeko. calificacion1REcalificacion2Acalificacion3E5calificacion4VVcalificacion5Acalificacion6OB07pler4twpwa2rdqpkcwmvhkxxd52gONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-06-14T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-07T03:46:23.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE&MANYa3aauuktnvama2 ENTITY{"identifier":"10032002","name":[{"value":"VV.AA","locale":"es_ES"}],"external_identifier":"2585228051","family_name":"VV.AA","birth_place":[],"death_place":[],"biography":[],"media_objects":[],"normalized_name":"vv.aa"}ONEa3novp2ls57ixm STRINGR[{"locale":"es_ES","value":"SIN ESTILO"}]ONEa4pp5rqvfzxxf6 NUMBER29ONEa5ej6iwjweshes STRING999ONEacnblp3uq557wk STRING999ONEadizbj7oydkivk STRING_VV.AA_MANYadst3cwky5lfja STRING[{"locale":"es_ES","value":["Gabán Bravo, Jesús","Hernández Pintor, Nuria","Inaraja i Genís, Christian"]}]ONEadwyeen33wnwra STRING216ONEaj6qadcmhrezii NUMBER48ONEajjkwpbdx2sews NUMBER158ONEamtwcchnrdjzfw ENTITY{"identifier":"g","name":[{"value":"g","locale":"es_ES"}],"external_identifier":"347187090","description":[{"value":"g","locale":"es_ES"}],"type_lookup":"206"}ONEangal4rqdmxpse STRINGR[{"locale":"es_ES","value":"SIN ESTILO"}]ONEaogwgan32v4m66 STRINGFVMANYaoyr2i73cpmiu6 ENTITY{"identifier":"Euskera","name":[{"value":"Euskera","locale":"es_ES"}],"external_identifier":"352583090","description":[{"value":"Euskera","locale":"es_ES"}],"type_lookup":"157"}ONEau4wikbtn4ylzk STRING|Koadernoa euskara. Lehen Hezkuntza 6, 3 Hiruhilekoa. BizigarriMANYavkyp3speudsm6COMPLEX{"a3lf5jp2cerkrw":[{"identifier":"País Vasco","name":[{"value":"País Vasco","locale":"es_ES"}],"external_identifier":"1166437090","description":[{"value":"País Vasco","locale":"es_ES"},{"value":"País Basco","locale":"pt_PT"}],"type_lookup":"414"}]}ONEavl7kh42fi2dm4 NUMBER22.5MANYa5n7q7yo7vv4mmCOMPLEX[{"locale":"es_ES","value":[{"aboxfxr6aqfxku":["Euskaran, ikasleei eraginkortasunez komunikatzen lagunduko dieten trebetasun linguistikoak garatzea du helburu Bizigarri proiektuak.Euskal hizkuntza eta literatura, komunikazioaren ikuspegitik, eta dagokion kultura-errealitatean kokatuta.Komunikazio-egoerak oinarri hartuta proposatutako jarduerak, ikasliburuko edukiak finkatzeko."]}]}]MANY*libros_iss_calculatedCOMPLEX{"name":"VV.AA","rol":"Autor","grouper":"author","normalize_name_grouper":"author|vv.aa"}Libros_ISS.SPEC_SECONDARY_TEMPLATE +es_ESVoluminoso348625090Voluminoso +es_ESVoluminoso401$000000000108018843(2022-10-07T03:46:23Z(2022-06-14T22:00:01Z$001025516055859 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H0a79670c-a509-4af2-a087-4d0aaa3684c7 DELETE<2023-09-02T17:31:08.778787930Z4dataloader-mongo-kafka-job62023-09-02T17:31:34.742237Z(mixer-gtin-agr-kfreeH79115d16-f29c-4dfc-bc5b-395e7e26867562023-09-02T17:39:19.210890Z,mixer-gtin-calc-pcsflmHaa5eb3d3-284f-482b-91b3-ee94a32befbc62023-09-02T17:39:23.325680Z,mixer-gtin-calc-pcsflmH8b0e53ca-f97e-4b5d-a828-8693b4221db362023-09-02T22:32:39.343355Z0mixer-product-calc-kfreeH507add07-4278-47e4-9d09-65020ee3c3af<2024-01-19T11:16:53.775912067Z$mixer-xsell-mixtriH271b0de4-124a-4897-ad8e-1be75bcb4ce262024-01-19T11:16:56.627013Z4mixer-packing-units-mixtriHd5e87089-451a-4771-9ebc-eb5ea841fb6a62024-01-19T11:18:27.553855Z.mixer-offer-badge-mixbiH15172a85-57cb-4169-b7f3-ae6a8ffbdb0b62024-01-19T11:21:27.486532Z.mixer-offer-badge-mixbiHbd8941ee-fd5d-4684-bfba-0c622c6cffd08ǢcLoffer(A41651025).publish_ends_extendedIVA02IGIC91 +11099001011040669516001201COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001011020111099044&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31820072090 +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31855841054 +11935 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png +es_ESFCERTIFICACION_OEKO-TEX_STANDARD_100 +es_ESHCertificación Oeko-tex Standard 100 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png002 +es_ESHCertificación Oeko-tex Standard 1008SUSTAINABILITY_MANUFACTURING"2021-11-07T23:00Z0888721432511Rosa +es_ESRosaRosa +es_ESRosaMaquillaje +es_ESMaquillaje356973090 +es_ESMaquillaje5991480543115 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___3115O2.png +es_ES COLOR_MAQUILLAJE +es_ES Color MaquillajeMaquillaje +es_ESMaquillaje0(2021-11-10T16:22:28Z +es_ES"TOP TIPO CAMISETA158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000888721432511$000001520936440044TRADICIONAL +es_ES COLOR_MAQUILLAJE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___3115O2.png240181656084511163454056 +HANRO +es_ES +Hanro +es_ES&Sujetadores sin aro999.39072748013 +es_ES&Sujetadores sin aro +7.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN<088872143251108887214325040888721432498088872143261008887214326030888721432597088872143276408887214326410888721432665088872143265808887214327570888721432740088872143276408887214326410888721432665088872143265808887214327570888721432740088872143290008887214328940888721432801088872143279508887214328180888721432917088872143290008887214328940888721432801088872143279508887214328180888721432917 +A41651025A41181810A41181810A41651071A41651071158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41651025 +es_ES&Sujetadores sin aro999.39072748013 +es_ES&Sujetadores sin aro +7.000 +es_ESSujetadores999.39072737013 +es_ESSujetadores 12.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0892950 +es_ES0HANRO INTERNATIONAL GMBH +es_ES"Top tipo camiseta +es_ESTop de microfibra muy suave y elástico. Deportivo y versatil, como ropa interior o para deportes ligeros. Combina con la braguita a juego de la misma serie.A4165102511163454056 +HANRO +es_ES +HANRO5437381600892950 +es_ES0HANRO INTERNATIONAL GMBH^CALLE HAUPTSTRASSE,17-6840 GOTZIS - (HUNGRIA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize 071810 +es_ES"Top tipo camiseta +es_ES"Top tipo camiseta +es_ESTop de microfibra muy suave y elástico. Deportivo y versatil, como ropa interior o para deportes ligeros. Combina con la braguita a juego de la misma serie. calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5AHcalificacion6FIPDN044E +es_ESEspañol044477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-17T00:53:02.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-18T00:53:02.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-27T04:42:16.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY + {"identifier":"Lavar máximo 40º","name":[{"value":"Lavar máximo 40º","locale":"es_ES"}],"external_identifier":"350583090","description":[{"value":"Lavar máximo 40º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxCuarenta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/___94922.png","size":"small"}],"description":[{"value":"Lavar Máximo 40º","locale":"es_ES"}],"identifier":"94922","name":[{"value":"LAVARMAXCUARENTA","locale":"es_ES"}],"external_identifier":"600207054"}}{"identifier":"No usar blanqueante","name":[{"value":"No usar blanqueante","locale":"es_ES"}],"external_identifier":"484894090","description":[{"value":"No usar blanqueante","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa3kybygykw5doe ENTITY{"identifier":"Top","name":[{"value":"Top","locale":"es_ES"}],"external_identifier":"23556456090","description":[{"value":"Top","locale":"es_ES"}],"type_lookup":"2505"}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Sujetadores sin aro","name":[{"value":"Sujetadores sin aro","locale":"es_ES"}],"external_identifier":"12873137090","description":[{"value":"Sujetadores sin aro","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sujetadores","name":[{"value":"Sujetadores","locale":"es_ES"}],"external_identifier":"2700632090","description":[{"value":"Sujetadores","locale":"es_ES"}],"type_lookup":"1599"}MANYaj3ufdvuwowrlw ENTITY{"identifier":"Sin aro","name":[{"value":"Sin aro","locale":"es_ES"}],"external_identifier":"2696269090","description":[{"value":"Sin aro","locale":"es_ES"}],"type_lookup":"1601"}ONEastcg34k65osv2 STRING[{"locale":"es_ES","value":"TOUCH FEELING"},{"locale":"pt_PT","value":"TOUCH FEELING"}]MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":95,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":5,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001520936440044(2022-03-27T04:42:16Z(2022-08-18T00:53:02Z(2022-08-17T00:53:02Z$001011020111099044001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore044H619f112d-d22f-4887-8344-b8e3d48e0097 DELETE<2023-09-02T17:14:57.867325129Z4dataloader-mongo-kafka-job62023-09-02T17:15:04.692378Z(mixer-gtin-agr-kfreeH788bd47b-34dd-41ae-8017-9931a16e66a862023-09-02T17:15:06.366387Z,mixer-gtin-calc-pcsflmH2b47bf77-0b27-4a3a-a486-420b3e94bd0f62023-09-02T17:15:13.804741Z,mixer-gtin-calc-pcsflmH0e3076a0-144d-46c7-a575-603877413a2362023-09-02T22:34:37.546369Z0mixer-product-calc-kfreeH68cdb955-a746-44da-b9c4-4114526e71d6<2024-01-19T11:16:54.694974898Z$mixer-xsell-mixtriH9a5cfa43-3df4-4696-8c20-7645b7533b1762024-01-19T11:16:56.684330Z4mixer-packing-units-mixtriH71931813-d1ed-486b-bf9e-2e17c19a64a462024-01-19T11:18:27.557226Z.mixer-offer-badge-mixbiH99f8dd14-5c61-41c0-a74a-55876395ba4462024-01-19T11:21:27.488530Z.mixer-offer-badge-mixbiH6201d811-ca8f-445f-bafe-e2a5e25382978ǢcLoffer(A40796750).publish_ends_extendedIVA02IGIC91 +00559001052142223235001154COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001052115400559148 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGINMulticolor +es_ESMulticolorMulticolor +es_ESMulticolorMulticolor +es_ESMulticolor352633090 +es_ESMulticolor598507054 +20205 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png +es_ES6COLOR_MULTICOLOR_SECUNDARIO +es_ES6Color Multicolor SecundarioMulticolor +es_ESMulticolor0(2022-04-22T10:57:57Z +es_ES*VESTIDO FELPA PP AMAR156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401808629406$000001517260170148TRADICIONAL +es_ES6COLOR_MULTICOLOR_SECUNDARIO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___20205O1.png240180862940642929208056(BABY EL CORTE INGLES +es_ES*Baby El Corte Inglés +es_ESVestidos999.39089419013 +es_ESVestidos +3.000 +es_ESBebé Niña999.39073120013 +es_ESBebé Niña +3.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNl843481618389324018087077082401808707685843481618386224018087075312401808707678843481618414284348161841598434816184128843481618391684348161838868434816183909240180870764784348161841118434816184135843481618387924018087076238434816184166843481618389324018087077082401808707685843481618386224018087075312401808707678843481618414284348161841598434816184128843481618391684348161838868434816183909240180870764784348161841118434816184135843481618387924018087076238434816184166240181001274624018100128072401810012777240181001275324018100127912401810012784240181001313224018100130712401810013101240181001312524018100130882401810013118240180850144324018085014502401808501429240180850139924018085013822401808501351 +A40803986A40803986A40945469A40945497A40784534156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40796750 +es_ESVestidos999.39089419013 +es_ESVestidos +3.000 +es_ESBebé Niña999.39073120013 +es_ESBebé Niña +3.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN5928071600929497 +es_ES@PEDRO MARTINEZ CANO MALAGA, S.L.CARRETERA AZUCARERA INTELHORCE 70-72,.-29004 POL.IND.GUADALHORCE MALAGA - MALAGA (ESPAñA)  +es_ES8Vestido de bebé niña felpa +es_ESVestido de bebé niña felpa. Braguita cubrepañal incluida hasta la talla 3 años (2-3)A4079675042929208056BABY ECI +es_ESBABY ECI5928071600929497 +es_ES@PEDRO MARTINEZ CANO MALAGA, S.L.CARRETERA AZUCARERA INTELHORCE 70-72,.-29004 POL.IND.GUADALHORCE MALAGA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize22J6201 +es_ES8Vestido de bebé niña felpa +es_ES8Vestido de bebé niña felpa +es_ESVestido de bebé niña felpa. Braguita cubrepañal incluida hasta la talla 3 años (2-3) +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5VV00N4792990904 Años +es_ES4 AñosE +es_ESEspañol190826520903-4 +es_ES3-418171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING(Fuerzo Rebajas 80822ONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-13T00:40:13.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-14T00:40:13.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-05-02T22:00:01.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Fantasía","name":[{"value":"Fantasía","locale":"es_ES"}],"external_identifier":"25521449090","description":[{"value":"Fantasía","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Vestidos","name":[{"value":"Vestidos","locale":"es_ES"}],"external_identifier":"349407090","description":[{"value":"Vestidos","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Bebé Niña","name":[{"value":"Bebé Niña","locale":"es_ES"}],"external_identifier":"477514090","description":[{"value":"Bebé Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Sin mangas","name":[{"value":"Sin mangas","locale":"es_ES"}],"external_identifier":"485204090","description":[{"value":"Sin mangas","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Vestidos","name":[{"value":"Vestidos","locale":"es_ES"}],"external_identifier":"344732090","description":[{"value":"Vestidos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517260170148(2022-05-02T22:00:01Z(2022-09-14T00:40:13Z(2022-09-13T00:40:13Z$001052115400559148001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore148H08c944db-76fc-4038-92fe-ad16ecb9fb62 DELETE<2023-09-02T17:21:24.541289022Z4dataloader-mongo-kafka-job62023-09-02T17:21:34.211831Z(mixer-gtin-agr-kfreeHdca59994-8497-4ae7-aa05-e70bf72cef9d62023-09-02T17:21:46.111409Z,mixer-gtin-calc-pcsflmH01f3066e-985b-4dba-9dd5-8d83b700551f62023-09-02T17:21:47.729657Z,mixer-gtin-calc-pcsflmH145120e7-f39e-4f54-9854-9ff7a4be436862023-09-02T21:53:35.341044Z0mixer-product-calc-kfreeH07c1c280-4598-4527-a109-0da226e44762<2024-01-19T11:16:56.444922215Z$mixer-xsell-mixtriHac687190-897a-40f2-acc4-41ba2c7eebe862024-01-19T11:16:56.550435Z4mixer-packing-units-mixtriHdf7be0b3-4af5-4b29-9628-9a11c718642062024-01-19T11:18:28.008119Z.mixer-offer-badge-mixbiHec1d2008-7206-42e8-95a8-1a7aa41b95d962024-01-19T11:21:27.490438Z.mixer-offer-badge-mixbiH3bbeb8fd-9557-4b53-aab3-e041332e04a38ǢcLoffer(A44336185).publish_ends_extendedIVA02IGIC91 +16320001082843227806001698(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001082869816320042&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31820070090 +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31845113054 +32406 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png +es_ES&POLYESTER_RECICLADO +es_ES&Polyester reciclado +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png020 +es_ES&Polyester reciclado:SUSTAINABILITY_CLOSING_CIRCLE"2022-06-28T22:00Z0196307190305 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2022-07-22T10:08:12Z +es_ESSHORT RUNNING26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000196307190305$000001532671070042TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401843907279187385056NEW BALANCE +es_ESNew Balance +es_ES Shorts999.14619997013 +es_ES Shorts +5.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESDDeportes - Contenedor rebajas OI22997.44869638011 +es_ESDDeportes - Contenedor rebajas OI22N +es_ESRunning997.32324456011 +es_ESRunning +6.000 +es_ESDeportes997.32324246011 +es_ESDeportes +9.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ESBDeportes - Especial Deportes OI22997.43764242011 +es_ES,Especial deportes oi22N +es_ESRopa deportiva997.32324452011 +es_ESRopa deportiva +3.000 +es_ESDeportes997.32324246011 +es_ESDeportes +9.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ESRopa deportiva997.40963448011 +es_ESRopa deportiva +3.000 +es_ESDeportes997.40925048011 +es_ESDeportes 11.000 +es_ES$Cross - Feliz 2023997.40925036011 +es_ESFeliz 2023CDNN +es_ESRopa997.41016309011 +es_ESRopa +2.000 +es_ESRunning997.40963455011 +es_ESRunning +9.000 +es_ESDeportes997.40925048011 +es_ESDeportes 11.000 +es_ES$Cross - Feliz 2023997.40925036011 +es_ESFeliz 2023CDNNN +es_ES +Mujer999.17528257013 +es_ES +Mujer +2.000 +es_ESRopa999.53820013 +es_ESRopa +3.000 +es_ESRunning999.53818013 +es_ESRunning 16.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESPDeportes - Contenedor 2as Rebajas OI2223997.45082266011 +es_ES:Contenedor 2as Rebajas OI2223N26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A44336185 +es_ES Shorts999.14619997013 +es_ES Shorts +5.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN5055171600248955 +es_ES(BROPORMA RETAIL S.L.jCALLE MURO,42-36800 REDONDELA - PONTEVEDRA (ESPAñA)  +es_ESVShort de Mujer All-Terrain 2in1 New Balance +es_ESEl short New Balance Impact Run AT 2 en 1 te ayuda a superar duros entrenamientos en pista, carreras largas y todas las distancias intermedias. Estos shorts para mujer tienen una cubierta liviana sobre un short interno incorporado con tecnología NB DRYx que absorbe la humedad para ayudar a mantenerte fresca y cómoda. Los bolsillos de fácil acceso en el pantalón corto interno brindan almacenamiento para nutrición y objetos de valor. Canaliza capas adicionales a través del túnel de almacenamiento para mantener las manos libres mientras tu carrera se intensifica.A44336185187385056NEW BALANCE +es_ESNEW BALANCE5055171600248955 +es_ES(BROPORMA RETAIL S.L.jCALLE MURO,42-36800 REDONDELA - PONTEVEDRA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeWS23274 +es_ESVShort de Mujer All-Terrain 2in1 New Balance +es_ESVShort de Mujer All-Terrain 2in1 New Balance +es_ESEl short New Balance Impact Run AT 2 en 1 te ayuda a superar duros entrenamientos en pista, carreras largas y todas las distancias intermedias. Estos shorts para mujer tienen una cubierta liviana sobre un short interno incorporado con tecnología NB DRYx que absorbe la humedad para ayudar a mantenerte fresca y cómoda. Los bolsillos de fácil acceso en el pantalón corto interno brindan almacenamiento para nutrición y objetos de valor. Canaliza capas adicionales a través del túnel de almacenamiento para mantener las manos libres mientras tu carrera se intensifica. +calificacion1Acalificacion2Acalificacion4VVcalificacion5AAcalificacion6MO00N479437090L +es_ESLE +es_ESEspañol479437090L +es_ESL477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2yONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-07-19T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-07-20T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-07-19T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Shorts","name":[{"value":"Shorts","locale":"es_ES"}],"external_identifier":"347853090","description":[{"value":"Shorts","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Shorts","name":[{"value":"Shorts","locale":"es_ES"}],"external_identifier":"2836854090","description":[{"value":"Shorts","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX {"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster reciclado","name":[{"value":"Poliéster reciclado","locale":"es_ES"}],"external_identifier":"391093090","description":[{"value":"Poliestere riciclato","locale":"it_IT"},{"value":"Recycled polyester","locale":"en_GB"},{"value":"Poliéster reciclado","locale":"es_ES"},{"value":"Polyester recyclé","locale":"fr_FR"},{"value":"Poliéster reciclado","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001532671070042"2022-07-19T22:00Z"2022-07-20T22:00Z"2022-07-19T22:00Z$001082869816320042001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore04208Hab235ce9-c616-46cd-b632-b22cf128ba91 DELETE<2023-09-02T17:05:36.427273101Z4dataloader-mongo-kafka-job62023-09-02T17:05:44.194223Z(mixer-gtin-agr-kfreeH1523cd63-c754-4b61-bd9e-9e31715c7b8e62023-09-02T17:05:51.631409Z,mixer-gtin-calc-pcsflmH568258de-4628-4567-b02a-db9939bb6c7b62023-09-02T17:05:57.911719Z,mixer-gtin-calc-pcsflmHec122f93-1698-404b-af23-df7335c683de62023-09-02T22:18:29.140877Z0mixer-product-calc-kfreeHc8a7b7fd-4d6e-4d43-bbdb-cfc2865f6717<2024-01-19T11:18:26.319573915Z$mixer-xsell-mixtriHd63072a4-eced-4f63-bd84-204e1dbe6ec162024-01-19T11:18:26.540030Z4mixer-packing-units-mixtriH0bead712-04ca-41a1-8c4f-c87270877c7262024-01-19T11:18:28.011378Z.mixer-offer-badge-mixbiH0aa83b78-0036-4b2e-8523-8f698223a02062024-01-19T11:21:27.491237Z.mixer-offer-badge-mixbiH55742fff-26f9-41ba-8b15-7da576c44cac8ǢcLoffer(A41172656).publish_ends_extendedIVA02IGIC91 +00772001054340272354001401COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001054340100772036&includeAsWebNovelty +es_ESNovedadDVD"2021-09-19T22:00Z8445110287194 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2021-09-20T18:43:58Z +es_ESTS_AILEA158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008445110287194$000001518576060036TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401811918757147145056DESIGUALmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/0/00001269350/00001269350419mM1011.jpg +es_ESDesigual +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41172656 +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0022144 +es_ESABASIC, S.A. +es_ESbCamiseta de mujer tul floral con manga abullonada +es_ESCamiseta sofisticada con punto smock que se adapta al cuerpo. Confeccionada en tul con estampado floral, muy femenina por su corte crop con manga abullonada.A41172656147145056DESIGUAL +es_ESDESIGUAL15134011600022144 +es_ESABASIC, S.A.CALLE PASSEIG DEL MARE NOSTRUM,15-08039 BARCELONA - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize22SWTKAO +es_ESbCamiseta de mujer tul floral con manga abullonada +es_ESbCamiseta de mujer tul floral con manga abullonada +es_ESCamiseta sofisticada con punto smock que se adapta al cuerpo. Confeccionada en tul con estampado floral, muy femenina por su corte crop con manga abullonada. calificacion1Acalificacion2Acalificacion3RIcalificacion4VVcalificacion5Bcalificacion62100N47925309036 +es_ES36E +es_ESEspañol479448090XS +es_ESXS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-21T03:08:16.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-22T03:08:16.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-02-03T05:04:56.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar en agua fría","name":[{"value":"Lavar en agua fría","locale":"es_ES"}],"external_identifier":"349555090","description":[{"value":"Lavar en agua fría","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado delicado","name":[{"value":"Planchado delicado","locale":"es_ES"}],"external_identifier":"351060090","description":[{"value":"Planchado delicado","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"Planchado delicado","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201606/28/23309_1_.png","size":"small"}],"description":[{"value":"Planchado delicado","locale":"es_ES"}],"identifier":"23309","name":[{"value":"PLANCHADO_DELICADO","locale":"es_ES"}],"external_identifier":"12615474054"}} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Flores","name":[{"value":"Flores","locale":"es_ES"}],"external_identifier":"9338924090","description":[{"value":"Flores","locale":"es_ES"}],"type_lookup":"2504"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":93,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":7,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518576060036(2022-02-03T05:04:56Z(2022-09-22T03:08:16Z(2022-09-21T03:08:16Z$001054340100772036001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore036H557d4d72-57b0-4c5a-84fa-248a670c5efa DELETE<2023-09-02T17:26:09.229280213Z4dataloader-mongo-kafka-job62023-09-02T17:26:23.310306Z(mixer-gtin-agr-kfreeH2cff84ef-7890-42a4-babc-cb08170fdea262023-09-02T17:28:20.904820Z,mixer-gtin-calc-pcsflmH27f15bfb-82cc-452e-91f0-85fd846845cd62023-09-02T17:28:21.009308Z,mixer-gtin-calc-pcsflmH4644662b-9b7d-45d7-a260-ec0fab13ec3562023-09-02T22:16:05.274641Z0mixer-product-calc-kfreeH71a63835-2721-457b-a36d-c70f3e6a82c1<2024-01-19T11:18:26.616696176Z$mixer-xsell-mixtriH040aa35f-ba4a-4052-812c-75e6501bfa5b62024-01-19T11:18:26.829614Z4mixer-packing-units-mixtriH51dd80a5-ecef-4d95-987e-926b02540ed062024-01-19T11:18:28.015153Z.mixer-offer-badge-mixbiHdbf5b568-5ca2-4754-9df4-a5335fb5d53362024-01-19T11:21:27.492027Z.mixer-offer-badge-mixbiH51559003-62fa-4618-8c95-c0efe85f4c8e8Ǣcn +$+ +}&Loffer(A36507501).publish_ends_extendedIVA02IGIC91 +07128001025238688167001386COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001025238607128 &includeAsWebNovelty +es_ESNovedadDVD"2020-07-28T22:00Z8435000145888 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2021-04-08T10:02:02Z +es_ES$GORRA SEVILLA F.C.26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008435000145888$000000000150296879TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401770831005123744056NIKEmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201407/29/1248768132_2_.jpg +es_ESNike +es_ESAccesorios999.53781013 +es_ESAccesorios 12.000 +es_ESFútbol999.53778013 +es_ESFútbol 19.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ES Gorras999.53698013 +es_ES Gorras +6.000 +es_ESComplementos999.53692013 +es_ESComplementos +9.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESDeportes997.42247120011 +es_ESDeportes 16.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A36507501 +es_ESAccesorios999.53781013 +es_ESAccesorios 12.000 +es_ESFútbol999.53778013 +es_ESFútbol 19.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN0152660 +es_ES0SEVILLA FUTBOL CLUB, SAD +es_ES*Gorra Sevilla FC Nike +es_ESGorra Sevilla FC , anima a tu equipo con esta gorra con el logo en grandeA36507501123744056NIKE +es_ESNIKE0152660 +es_ES0SEVILLA FUTBOL CLUB, SAD998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos943092 - 451 +es_ES*Gorra Sevilla FC Nike +es_ES*Gorra Sevilla FC Nike +es_ESGorra Sevilla FC , anima a tu equipo con esta gorra con el logo en grande calificacion1A3calificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO06pler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-09-15T05:01:27.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-16T05:01:27.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-04-08T10:10:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Sevilla FC","name":[{"value":"Sevilla FC","locale":"es_ES"}],"external_identifier":"12306998090","description":[{"value":"Sevilla FC","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Gorras","name":[{"value":"Gorras","locale":"es_ES"}],"external_identifier":"373458090","description":[{"value":"Gorras","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Gorros y Sombreros","name":[{"value":"Gorros y Sombreros","locale":"es_ES"}],"external_identifier":"2811742090","description":[{"value":"Gorros y Sombreros","locale":"es_ES"}],"type_lookup":"1599"}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000150296879"2021-04-08T10:10Z(2022-09-16T05:01:27Z(2022-09-15T05:01:27Z$001025238607128 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hb6083d28-cbf3-46ef-97a9-97f93b08b1db DELETE<2023-09-02T17:23:51.331824726Z4dataloader-mongo-kafka-job62023-09-02T17:23:59.395645Z(mixer-gtin-agr-kfreeH2aa06dbd-8561-41ba-a536-f79c51ad329662023-09-02T17:25:43.523743Z,mixer-gtin-calc-pcsflmHd90f0139-77fe-43ce-9c59-f97296502ffb62023-09-02T17:25:49.310197Z,mixer-gtin-calc-pcsflmH69e1ea73-4db1-4f1d-9f34-73d399b9093562023-09-03T02:41:48.138205Z0mixer-product-calc-kfreeH0bbcdd23-12be-4cf0-9246-2fa60e3a02ff<2024-01-19T11:17:59.965756983Z$mixer-xsell-mixtriH0ac88ca7-91ca-4e80-8e18-f415ef3b8a9962024-01-19T11:18:01.311349Z4mixer-packing-units-mixtriH3e54f155-0466-47c8-aa1c-42bb475e1fd162024-01-19T11:18:28.148237Z.mixer-offer-badge-mixbiH251b82fb-396e-4224-8d51-86f11440178f62024-01-19T11:21:27.492835Z.mixer-offer-badge-mixbiH5e59a0e7-e8bb-4f26-8660-66e1577891a88ǢcLoffer(A40611043).publish_ends_extendedIVA02IGIC91 +00791001041541835230001157COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001041515700791003&includeAsWebNovelty +es_ESNovedadDVDNaranjas +es_ESNaranjasNaranjas +es_ESNaranjasNaranja +es_ESNaranja347412090 +es_ESNaranja596745054 +10150 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___10150O4.png +es_ESCOLOR_NARANJA +es_ESColor NaranjaNaranja +es_ESNaranja0(2022-03-09T10:54:34Z +es_ES$SHORT FELPA BASIC158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401806788426$000001516585140003TRADICIONAL +es_ESCOLOR_NARANJA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___10150O4.png2401806788426124448056EASY WEARmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/1/00001269351/00001269351363mM1011.jpg +es_ESEasy Wear +es_ES Short y Bermudas999.39090708013 +es_ES Short y Bermudas 27.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESLoungewear999.39090783013 +es_ESLoungewear 29.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN001041514411234001017730300989158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40611043 +es_ES Short y Bermudas999.39090708013 +es_ES Short y Bermudas 27.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN5915061600907659 +es_ES>BERTOLIN GARCIA, GABRIEL CARLOSAVENIDA PEREZ GALDOS, 103 - PTA.34,.-46018 VALENCIA - VALENCIA (ESPAñA)  +es_ES>Short básico de felpa de mujer +es_ESrShort básico de felpa en color liso y cintura elástica.A40611043124448056EASY WEAR +es_ESEASY WEAR5915061600907659 +es_ES>BERTOLIN GARCIA, GABRIEL CARLOSAVENIDA PEREZ GALDOS, 103 - PTA.34,.-46018 VALENCIA - VALENCIA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeS22-1005-P +es_ES>Short básico de felpa de mujer +es_ES>Short básico de felpa de mujer +es_ESrShort básico de felpa en color liso y cintura elástica. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AD00N47925309036 +es_ES36E +es_ESEspañol479443090S +es_ESS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-21T00:45:10.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-22T00:45:10.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-04-12T13:36:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Shorts y Bermudas","name":[{"value":"Shorts y Bermudas","locale":"es_ES"}],"external_identifier":"2700621090","description":[{"value":"Shorts y Bermudas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":60.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":40.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001516585140003"2022-04-12T13:36Z(2022-09-22T00:45:10Z(2022-09-21T00:45:10Z$001041515700791003001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore003H24dac5bb-9773-41ef-9112-4b2c50a6e7be DELETE<2023-09-02T17:25:50.496865894Z4dataloader-mongo-kafka-job62023-09-02T17:25:57.219275Z(mixer-gtin-agr-kfreeH172d429f-4856-4d43-a6de-ab86c53e4f1762023-09-02T17:26:04.720241Z,mixer-gtin-calc-pcsflmH9f4f74c9-b658-4339-9aec-e025177c9ca062023-09-02T17:26:06.524793Z,mixer-gtin-calc-pcsflmH17bceba6-ccf8-4bf7-bebd-d8a40bd1a8d962023-09-03T02:41:57.458606Z0mixer-product-calc-kfreeH3d2e3299-01af-4a7e-a8ce-fa9d3087d32c<2024-01-19T11:17:59.985623692Z$mixer-xsell-mixtriHe0f66072-af7c-4b8f-a77d-e455781b324162024-01-19T11:18:01.316409Z4mixer-packing-units-mixtriHafdcb4ee-3413-4399-ab32-c6c1575da55062024-01-19T11:18:28.149105Z.mixer-offer-badge-mixbiHbfde2992-402b-4e16-9125-dbacbfd42f0762024-01-19T11:21:27.493507Z.mixer-offer-badge-mixbiHd7def80d-41c2-449d-a9ea-bf2513c64db78ǢcIVA02IGIC91 +1168800102023-02-12T04:50:06.484Z099231849040001201COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001099220111688014&includeAsWebNovelty +es_ESNovedadDVD"2019-02-10T23:00Z5713775906457 Grises +es_ES Grises Grises +es_ES GrisesGris +es_ESGris344777090 +es_ESGris5996500544940 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png +es_ESCOLOR_GRIS +es_ESColor GrisGris +es_ESGris0(2019-05-27T16:21:28Z +es_ES*NKMVERMO AOP SWE LONG +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005713775906457$000001479921510014TRADICIONAL +es_ESCOLOR_GRIS +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___4940O3.png240171416416924009642056NAME IT +es_ESname it +es_ES$PantalonesBermudas999.2680963013 +es_ES*Pantalones y Bermudas +1.000 +es_ES$Niño (1-16 años)999.2680820013 +es_ES$Niño (1-16 años) +3.000 +es_ES2014 Infantil999.2680809013 +es_ESInfantil +3.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ESBermudas999.39089916013 +es_ESBermudas 15.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A304582716212151600502534 +es_ES>BESTSELLER WHOLESALE SPAIN,S.L.fCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA)  +es_ESTBermuda de niño Name It en gris camuflaje +es_ESBermuda de niño gris en algodón estampada con motivo de camuflaje. Lleva cinturilla interior ajustable, bolsillos, cordón decorativo y detalle de vuelta en el bajo.A3045827124009642056NAME IT +es_ESNAME IT6212151600502534 +es_ES>BESTSELLER WHOLESALE SPAIN,S.L.fCALLE ARGELIA,2-29140 CHURRIANA - MALAGA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize13164756 +es_ESTBermuda de niño Name It en gris camuflaje +es_ESTBermuda de niño Name It en gris camuflaje +es_ESBermuda de niño gris en algodón estampada con motivo de camuflaje. Lleva cinturilla interior ajustable, bolsillos, cordón decorativo y detalle de vuelta en el bajo. +calificacion1F0calificacion2Acalificacion3RPcalificacion4VVcalificacion5VV0047912709014 Años +es_ES14 AñosE +es_ESEspañol19040058090 +13-14 +es_ES +13-1418171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-07-12T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-07-19T06:22:10.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02019-05-24T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Militar","name":[{"value":"Militar","locale":"es_ES"}],"external_identifier":"9338926090","description":[{"value":"Militar","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bermudas","name":[{"value":"Bermudas","locale":"es_ES"}],"external_identifier":"352535090","description":[{"value":"Bermudas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones y Bermudas","name":[{"value":"Pantalones y Bermudas","locale":"es_ES"}],"external_identifier":"2700611090","description":[{"value":"Pantalones y Bermudas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2019Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001479921510014"2019-05-24T22:00Z(2019-07-19T06:22:10Z"2019-07-12T22:00Z$001099220111688014001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore014H9303ac06-1a23-431a-ad92-c4f40b048e94 DELETE<2023-09-02T17:12:09.074434259Z4dataloader-mongo-kafka-job62023-09-02T17:12:19.388443Z(mixer-gtin-agr-kfreeHdedcbfc5-b2d5-4110-b6f3-4dde3321752d62023-09-02T17:12:22.210834Z,mixer-gtin-calc-pcsflmH25dff6a9-bef9-46cc-b2ab-df33b2d4450e62023-09-02T17:12:33.112174Z,mixer-gtin-calc-pcsflmHe78595cc-2dae-47e8-96e2-0e28012a1b7562023-09-03T02:30:22.451429Z0mixer-product-calc-kfreeHdccf11ea-fba9-4efe-a94a-25eec8f019e1<2024-01-19T11:18:00.865066181Z$mixer-xsell-mixtriHec4a6014-5029-4940-b441-8721cd3082b762024-01-19T11:18:01.401295Z4mixer-packing-units-mixtriHe053a857-b740-4e35-9e53-beb34fc4f4ba62024-01-19T11:18:28.212483Z.mixer-offer-badge-mixbiHbaa12a8e-0df9-4f35-98a7-b2450eec628762024-01-19T11:21:27.495299Z.mixer-offer-badge-mixbiHc5a23e32-4cab-4387-8fab-46d8af2c12058ǢcLoffer(A41324510).publish_ends_extendedIVA02IGIC91 +00448001089941866440001851COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001089985100448018 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN"2021-10-04T22:00Z8445525502387 +Rojos +es_ES +Rojos +Rojos +es_ES +RojosRojo +es_ESRojo344736090 +es_ESRojo599025054 +25344 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___25344O3.png +es_ESCOLO_ROJO +es_ESColo RojoRojo +es_ESRojo0(2022-03-11T11:32:55Z +es_ES*BLUSA ONDAS CON BORDA156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008445525502387$000001519443220018TRADICIONAL +es_ESCOLO_ROJO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___25344O3.png24018134557482307390056 +SFERAmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA01/201309/13/1377521437_1_.jpg +es_ES +Sfera +es_ES Blusas999.39089557013 +es_ES Blusas +1.000 +es_ES Blusas y camisas999.39089556013 +es_ES Blusas y camisas 14.000 +es_ESBebé Niña999.39073120013 +es_ESBebé Niña +3.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41324510 +es_ES Blusas999.39089557013 +es_ES Blusas +1.000 +es_ES Blusas y camisas999.39089556013 +es_ES Blusas y camisas 14.000 +es_ESBebé Niña999.39073120013 +es_ESBebé Niña +3.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN0935965 +es_ES$MEENU CREATION LLP +es_ES@Blusa ondas mixto de bebé niña +es_ESBlusa combinada con tirantes y ranita a contraste. Algodón 100%.A413245102307390056 +SFERA +es_ES +SFERA0935965 +es_ES$MEENU CREATION LLP998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize21B5702 +es_ES@Blusa ondas mixto de bebé niña +es_ES@Blusa ondas mixto de bebé niña +es_ESBlusa combinada con tirantes y ranita a contraste. Algodón 100%. calificacion1Acalificacion2INcalificacion3RVcalificacion4VVcalificacion5AFcalificacion6B200N47916209018 Meses +es_ES18 MesesE +es_ESEspañol47916209018 Meses +es_ES18 Meses477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING(Fuerzo Rebajas 80822ONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-05-02T22:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-09T04:06:06.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-05-02T22:00:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEac5swxsdtmjapu ENTITY{"identifier":"Blusas","name":[{"value":"Blusas","locale":"es_ES"}],"external_identifier":"2682030090","description":[{"value":"Blusas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Bebé Niña","name":[{"value":"Bebé Niña","locale":"es_ES"}],"external_identifier":"477514090","description":[{"value":"Bebé Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Blusas y Camisas","name":[{"value":"Blusas y Camisas","locale":"es_ES"}],"external_identifier":"382173090","description":[{"value":"Blusas y Camisas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001519443220018(2022-05-02T22:00:01Z(2022-08-09T04:06:06Z(2022-05-02T22:00:01Z$001089985100448018001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore018H734b7df7-b633-4263-a2bd-53d1edb0c9e4 DELETE<2023-09-02T17:11:02.507974706Z4dataloader-mongo-kafka-job62023-09-02T17:11:13.659426Z(mixer-gtin-agr-kfreeHcb18c640-6e1d-4e48-8638-e2d64d60e55862023-09-02T17:11:15.714483Z,mixer-gtin-calc-pcsflmH8fb9cdd8-079f-451a-94fe-0eae53dfef0e62023-09-02T17:11:24.425792Z,mixer-gtin-calc-pcsflmHa86c9e0e-7984-42f9-a9a7-9e296d76612b62023-09-03T02:53:53.183872Z0mixer-product-calc-kfreeH39315e81-d7ba-4966-a3c3-e68482e811a2<2024-01-19T11:18:27.073016947Z$mixer-xsell-mixtriH1315f874-e5f3-4b62-bcdc-08de6c0cfde562024-01-19T11:18:27.270055Z4mixer-packing-units-mixtriHdcd1a30e-d53e-4d4b-8246-10971a51851e62024-01-19T11:18:28.040546Z.mixer-offer-badge-mixbiH5c6f68f9-63da-4bf6-ad44-bae94d5b4ebf62024-01-19T11:21:27.585349Z.mixer-offer-badge-mixbiHfe0b6ac0-9c9b-4476-8812-25f214e16ecb8ǢcLoffer(A40915791).publish_ends_extendedIVA02IGIC91 +23929001010441175433001408COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001010440823929036&includeAsWebNovelty +es_ESNovedadDVD"2021-08-23T22:00Z0195252916350 +Rosas +es_ES +Rosas +Rosas +es_ES +RosasRosa +es_ESRosa347700090 +es_ESRosa5985060542019 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png +es_ESCOLOR_ROSA +es_ESColor RosaRosa +es_ESRosa0(2022-01-03T11:18:01Z +es_ES*RIVAL + FLEECE HOODIE26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000195252916350$000001517621070036TRADICIONAL +es_ESCOLOR_ROSA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/10/___2019.png2401809723448136537056UNDER ARMOURmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201408/14/1288947042_4_.jpg +es_ESUnder Armour + +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESSudaderas999.14620000013 +es_ESSudaderas +7.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES +Mujer999.17368063013 +es_ES +Mujer +2.000 +es_ESRopa training999.52215013 +es_ESRopa training 20.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESDeportes997.42247120011 +es_ESDeportes 16.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESRopa deportiva997.41811698011 +es_ESRopa deportiva +1.000 +es_ESDeportes997.41799406011 +es_ESDeportes +4.000 +es_ES.Cross - Ganas de Fase 1997.41799402011 +es_ES.Cross - Ganas de Fase 1CDNN26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40915791 +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN0901922 +es_ES0UNDER ARMOUR EUROPE B.V. +es_ESVSudadera de mujer Rival Fleece Under Armour +es_ESEs la prenda perfecta para calentar o hacer cualquier otra cosa: es ligera, cómoda y presenta un interior supersuave.Tejido fleece de mezcla de algodón ultrasuave y de peso medio, con interior cepillado para una mayor calidez. Paneles de malla laterales y bajo las axilas que añaden transpirabilidad. Bolsillo delantero tipo canguro. Bajo ajustable. Puños acanalados. Mangas raglánA40915791136537056UNDER ARMOUR +es_ESUNDER ARMOUR8803251600901922 +es_ES0UNDER ARMOUR EUROPE B.V.rCALLE STADIONPLEIN,10- AMSTERDAM -1076 - (PAISES BAJOS) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize1369851-676 +es_ESVSudadera de mujer Rival Fleece Under Armour +es_ESVSudadera de mujer Rival Fleece Under Armour +es_ESEs la prenda perfecta para calentar o hacer cualquier otra cosa: es ligera, cómoda y presenta un interior supersuave.Tejido fleece de mezcla de algodón ultrasuave y de peso medio, con interior cepillado para una mayor calidez. Paneles de malla laterales y bajo las axilas que añaden transpirabilidad. Bolsillo delantero tipo canguro. Bajo ajustable. Puños acanalados. Mangas raglán calificacion1Acalificacion2Acalificacion3RTcalificacion4VVcalificacion5Bcalificacion6MO06N479448090XS +es_ESXSE +es_ESEspañol479448090XS +es_ESXS477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-09-15T00:57:13.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-16T00:57:13.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-12-31T23:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"347714090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"485392090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":80.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":20.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517621070036"2021-12-31T23:00Z(2022-09-16T00:57:13Z(2022-09-15T00:57:13Z$001010440823929036001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore036Hdc8d2248-a45e-4912-acfb-cb1654dfd806 DELETE<2023-09-02T17:22:07.783288648Z4dataloader-mongo-kafka-job62023-09-02T17:22:17.776354Z(mixer-gtin-agr-kfreeH3e9be04e-3a46-4f8d-bda8-df4436b8c9d462023-09-02T17:22:54.805676Z,mixer-gtin-calc-pcsflmH0cda3398-5bf8-4c2e-bda3-388e3c1dbd8362023-09-02T17:22:57.321323Z,mixer-gtin-calc-pcsflmHf1d04fe1-cc85-4ccd-b627-143c71fcd90562023-09-03T02:49:26.360774Z0mixer-product-calc-kfreeH8e3a791e-f907-4643-8fc7-42c259a5238c<2024-01-19T11:18:07.647399764Z$mixer-xsell-mixtriH79f906ea-d7b5-471b-b405-823c3a8382d862024-01-19T11:18:07.700568Z4mixer-packing-units-mixtriH120a1aa0-959e-4787-ab1f-3a32c3a90e3462024-01-19T11:18:28.531042Z.mixer-offer-badge-mixbiH9faf883a-ecee-4110-84a7-9070a4739d5162024-01-19T11:21:27.591701Z.mixer-offer-badge-mixbiH79d4f354-66fb-4ecd-baef-2a327cf4cfeb8ǢcLoffer(A43145994).publish_ends_extendedIVA02IGIC92 +06492001A094641838117001108COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001094610806492 &includeAsWebNovelty +es_ESNovedadDVD"2022-03-08T23:00Z0194253023456 Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2022-03-09T12:11:16Z +es_ES*CORREA SPORT BAND 45M26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000194253023456$000000000152745324TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401831920549124603056 +Apple +es_ES +Apple +es_ES$Relojes deportivos999.52184013 +es_ES$Relojes deportivos +2.000 +es_ES,Electrónica Deportiva999.53868013 +es_ES,Electrónica deportiva 10.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ES$Correas Smartwatch999.43675487013 +es_ES$Correas Smartwatch +3.000 +es_ESSmartwatches999.23716187013 +es_ESSmartwatches +5.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNN26 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43145994 +es_ES$Relojes deportivos999.52184013 +es_ES$Relojes deportivos +2.000 +es_ES,Electrónica Deportiva999.53868013 +es_ES,Electrónica deportiva 10.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN0904813 +es_ES@APPLE DISTRIBUTION INTERNATIONAL +es_ESCorrea deportiva Apple en color Azul Niebla para Apple Watch de 45 mm - Talla única +es_ESCorrea deportiva Apple en color Azul Niebla para Apple Watch de 45 mm - Talla únicaPara esta correa decidimos utilizar un fluoroelastómero especial de alto rendimiento que la hace fuerte y resistente, a la vez que muy suave. Este material flexible y agradable al tacto se adapta con elegancia a la forma de tu muñeca. Un práctico cierre de clip completa su impecable diseño minimalista. +pt_PTSPORT BAND 45MPara esta cinta decidimos utilizar um fluoroelastómero especial de alto desempenho que a torna forte e durável, mas muito macia. Este material flexível e agradável ao toque adapta-se elegantemente à forma do seu pulso. Um prático grampo de fixação completa o seu design minimalista impecável.A43145994124603056 +APPLE +es_ES +APPLE5448901600904813 +es_ES@APPLE DISTRIBUTION INTERNATIONALCALLE LG HOLLY INDUSTRIAL STATE,..- HOLLYHILL, CORK - (ITALIA) 998.00092 +es_ESGenerico998.00081 +es_ESInformática998 +es_ES@Jerarquía de Ficha de Productos +años +es_ES +años +3.000MN2D3ZM/A +es_ESCorrea deportiva Apple en color Azul Niebla para Apple Watch de 45 mm - Talla únicaMN2D3ZM/A +es_ESCorrea deportiva Apple en color Azul Niebla para Apple Watch de 45 mm - Talla única +es_ESCorrea deportiva Apple en color Azul Niebla para Apple Watch de 45 mm - Talla únicaPara esta correa decidimos utilizar un fluoroelastómero especial de alto rendimiento que la hace fuerte y resistente, a la vez que muy suave. Este material flexible y agradable al tacto se adapta con elegancia a la forma de tu muñeca. Un práctico cierre de clip completa su impecable diseño minimalista. +pt_PTSPORT BAND 45MPara esta cinta decidimos utilizar um fluoroelastómero especial de alto desempenho que a torna forte e durável, mas muito macia. Este material flexível e agradável ao toque adapta-se elegantemente à forma do seu pulso. Um prático grampo de fixação completa o seu design minimalista impecável. calificacion1C1calificacion2Ecalificacion3M5calificacion4VVcalificacion5EScalificacion64N06N +pjej4owgwj3w3wpler4twpwa2rdqpjwsk3sxxsoxg4phm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-04-18T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-26T05:08:29.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-08T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa53raak6wnanvg ENTITY{"identifier":"Correa","name":[{"value":"Correa","locale":"es_ES"}],"external_identifier":"32526297090","description":[{"value":"Correa","locale":"es_ES"}],"type_lookup":"579"}Generico_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000152745324"2022-03-08T23:00Z(2022-08-26T05:08:29Z"2022-04-18T22:00Z$001094610806492 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H3fad6bb8-53b7-481d-a7d1-97c3b1e08754 DELETE<2023-09-02T17:17:16.539320614Z4dataloader-mongo-kafka-job62023-09-02T17:17:25.762042Z(mixer-gtin-agr-kfreeHb2b2b624-474b-42d2-9506-2fc22f3ac7f462023-09-02T17:17:29.212479Z,mixer-gtin-calc-pcsflmH85107315-0dcc-41ed-96c9-3cabb71bfa1c62023-09-02T17:17:33.517263Z,mixer-gtin-calc-pcsflmH9a592267-ee2c-4fd7-8a90-0e5b6fcff70162023-09-03T02:33:33.550850Z0mixer-product-calc-kfreeH58245b9a-d5d6-4e48-83f8-f27098857272<2024-01-19T11:18:07.907297920Z$mixer-xsell-mixtriH6d9df486-4e1a-4e52-a7f0-ad6282c2fec162024-01-19T11:18:08.014553Z4mixer-packing-units-mixtriH32f9f054-84b5-4543-9e47-fcd4e7ef7f4062024-01-19T11:18:28.534438Z.mixer-offer-badge-mixbiHf4136508-3423-4223-b2d0-e42690b0a9a262024-01-19T11:21:27.592328Z.mixer-offer-badge-mixbiHdefbd9ec-0d06-4ce9-a1d3-57fdf8789c588ǢcIVA08IGIC90 +4316400102023-03-21T03:16:27.151Z0065971261001120COMPRA EN FIRME +es_ESCOMPRA EN FIRME*LECTURAS RECOMENDADAS +es_ES*LECTURAS RECOMENDADASSTERLING +es_ESSTERLING$001006512043164 "2018-02-07T23:00Z97820671482460(2012-03-12T12:14:18Z +es_ES*MINI ATLAS FRANCIA 95 +es_ES Libros274977090 Libros3959782067148246$0000000001006888302401343357970578939056MICHELIN +es_ESMichelin +es_ESXGuías Anuales y Publicaciones de Referencia999.6866342013 +es_ESXGuías Anuales y Publicaciones de Referencia +4.000 +es_ES Viajes y turismo999.6866333013 +es_ES Viajes y turismo 49.000 +es_ES Libros999.54302013 +es_ES LibrosNNN +es_ES Libros274977090 Libros395A44344805579081602024869 +es_ESMICHELIN ,- - ()  +es_ES:Mini atlas francia 95 fr 2010A4434480578939056MICHELIN +es_ESMICHELIN4851111600029942 +es_ES,EUSKAL KULTURGINTZA SAxCALLE PORTUETXE,88-20018 SAN SEBASTIAN - GIPUZKOA (ESPAñA) 998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de ProductosB9782067148246 +es_ES:Mini atlas francia 95 fr 2010 +es_ES:Mini atlas francia 95 fr 2010 +calificacion1Acalificacion2Ecalificacion3E5calificacion4VVcalificacion5B06pler4twpwa2rdqpkcwmvhkxxd52gpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02014-10-28T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02014-10-29T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02010-03-07T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa3aauuktnvama2 ENTITY{"identifier":"0030338","name":[{"value":"MICHELIN","locale":"es_ES"}],"external_identifier":"315409051","family_name":"MICHELIN","birth_place":[],"death_place":[],"biography":[],"media_objects":[],"normalized_name":"michelin"}ONEa3novp2ls57ixm STRINGt[{"locale":"es_ES","value":"PUBLICACIONES DE REFERENCIA"}]ONEa5ej6iwjweshes STRING000ONEacnblp3uq557wk STRING014ONEadizbj7oydkivk STRING_MICHELIN_ONEadwyeen33wnwra STRING005ONEangal4rqdmxpse STRING^[{"locale":"es_ES","value":"TURISMO Y VIAJES"}]ONEaogwgan32v4m66 STRINGDSMANYaoyr2i73cpmiu6 ENTITY{"identifier":"Castellano","name":[{"value":"Castellano","locale":"es_ES"}],"external_identifier":"347423090","description":[{"value":"Castellano","locale":"es_ES"}],"type_lookup":"157"}ONEau4wikbtn4ylzk STRING:Mini atlas francia 95 fr 2010MANY*libros_iss_calculatedCOMPLEX{"name":"MICHELIN","rol":"Autor","grouper":"author","normalize_name_grouper":"author|michelin"}Libros_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000100688830"2010-03-07T23:00Z"2014-10-29T23:00Z"2014-10-28T23:00Z$001006512043164 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H2054f8f6-daf3-457c-9bfd-e8aa421b4170 DELETE<2023-09-02T17:24:00.783194142Z4dataloader-mongo-kafka-job62023-09-02T17:24:10.493512Z(mixer-gtin-agr-kfreeHea57e916-e6f3-4cf6-b34c-384abeaa629c62023-09-02T17:24:18.318345Z,mixer-gtin-calc-pcsflmHefdda695-c8c8-4b38-bfd4-1f6a060b983962023-09-02T17:24:27.010051Z,mixer-gtin-calc-pcsflmH069cd448-3cf0-41df-a7a8-9a996fc2724d62023-09-03T02:45:46.339218Z0mixer-product-calc-kfreeHdbf19967-f590-460d-93c1-db9c5e9b9afa<2024-01-19T11:18:07.668789584Z$mixer-xsell-mixtriH4a7f558e-c0a5-49a4-86ae-450a50a7e3d162024-01-19T11:18:08.164525Z4mixer-packing-units-mixtriH1ae2f74d-dfdf-4c52-975b-378cd68dc36462024-01-19T11:18:28.535436Z.mixer-offer-badge-mixbiHfb560607-c48e-431f-bd99-071b24755e0f62024-01-19T11:21:27.592871Z.mixer-offer-badge-mixbiHa77efbcf-b56a-4675-af0a-76a27a1daf518ǢcIVA02IGIC92"2014-02-06T23:01Z +3215100102023-02-20T07:30:55.153ZA09752655432001755COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001097575532151 &includeAsWebNovelty +es_ESNovedadDVD"2015-06-04T22:00Z5051893221268"2014-01-14T23:00Z2975755321510"2014-01-14T23:00Z50518931650740(2014-01-17T08:28:16Z +es_ES*LEGO MOVIE: THE VIDEO +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005051893221268$000000000105416598240150396469716963744056"WARNER BROS GAMES +es_ES"Warner Bros Games  +es_ES"Videojuegos, Lego997.12393107011 +es_ESLegoCD +es_EShVideojuegos, Liquidación Videojuegos Noviembre 2019997.32793599011 +es_ES$Outlet VideojuegosCD +es_ES Juegos997.32798013011 +es_ES Juegos +2.000 +es_EShVideojuegos, Liquidación Videojuegos Noviembre 2019997.32793599011 +es_ES$Outlet VideojuegosCDN +es_ES Juegos999.53536013 +es_ES Juegos +2.000 +es_ESPlayStation 3999.53978013 +es_ESPS3 33.000 +es_ESVideojuegos999.51648013 +es_ESVideojuegosNNN +es_ESJLego La Lego Película: El Videojuego997.12509009011 +es_ESJLego La Lego Película: El Videojuego 16.000 +es_ES"Videojuegos, Lego997.12393107011 +es_ESLegoCDN +es_ESVer todo Lego997.40354834011 +es_ESVer todo Lego +1.000 +es_ES"Videojuegos, Lego997.12393107011 +es_ESLegoCDN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A115480995835201600172569 +es_ES6BODEGA MARTIN BERDUGO, S.L.AVENIDA MONASTERIO DE LAS HUELGAS,20-09001 BURGOS - BURGOS (ESPAñA)  +es_ES:LEGO Movie: The Videogame PS3 +es_ESTransforma lo ordinario en extraordinario y disfruta de una gran experiencia constructiva de LEGO con La LEGO Película: El Videojuego.Entra en el mundo de Emmet, un ciudadano medio, completamente ordinario, y que sigue las reglas a rajatabla, pero que será confundido con una de las personas más extraordinarias del mundo y la clave para salvar al mundo.Los jugadores deberán guiarle en una épica aventura para detener a un malvado tirano, un viaje para el que Emmet no está preparado."Características:Disfruta de más de 90 personajes diferentes que también aparecen en la película, incluyendo a Batman, Superman y Gandalf en más de 15 niveles.Revienta más bloques que nunca en un entorno fascinante hecho de bloques de LEGO.Colecciona y utiliza las páginas de instrucciones de LEGO para construir lo que imagines.Viaja a través de fantásticos mundos como Ladriburgo, La Nube Cucolandia y muchos más.Utiliza el increíble poder de los Maestros Constructores para construir extraordinarias creaciones de LEGO.Disfruta de una auténtica experiencia LEGO como nunca antes se ha visto, con un nuevo estilo de animación visual en el cual se recrea el movimiento de los juguetes LEGO de forma real.Juega con familia y amigos en el modo cooperativo en pantalla dividida.A115480995835201600172569 +es_ES6BODEGA MARTIN BERDUGO, S.L.AVENIDA MONASTERIO DE LAS HUELGAS,20-09001 BURGOS - BURGOS (ESPAñA) 998.00072 +es_ESVideojuegos998.00071 +es_ESVideojuegos998 +es_ES@Jerarquía de Ficha de Productos1000439824 +es_ES:LEGO Movie: The Videogame PS3 +es_ES:LEGO Movie: The Videogame PS3 +es_ESTransforma lo ordinario en extraordinario y disfruta de una gran experiencia constructiva de LEGO con La LEGO Película: El Videojuego.Entra en el mundo de Emmet, un ciudadano medio, completamente ordinario, y que sigue las reglas a rajatabla, pero que será confundido con una de las personas más extraordinarias del mundo y la clave para salvar al mundo.Los jugadores deberán guiarle en una épica aventura para detener a un malvado tirano, un viaje para el que Emmet no está preparado."Características:Disfruta de más de 90 personajes diferentes que también aparecen en la película, incluyendo a Batman, Superman y Gandalf en más de 15 niveles.Revienta más bloques que nunca en un entorno fascinante hecho de bloques de LEGO.Colecciona y utiliza las páginas de instrucciones de LEGO para construir lo que imagines.Viaja a través de fantásticos mundos como Ladriburgo, La Nube Cucolandia y muchos más.Utiliza el increíble poder de los Maestros Constructores para construir extraordinarias creaciones de LEGO.Disfruta de una auténtica experiencia LEGO como nunca antes se ha visto, con un nuevo estilo de animación visual en el cual se recrea el movimiento de los juguetes LEGO de forma real.Juega con familia y amigos en el modo cooperativo en pantalla dividida. +calificacion1Acalificacion2Ocalificacion3M5calificacion4VVcalificacion5B06pjej4owgwj3w3wpler4twpwa2rdqp3dnlg7a5teleqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02019-04-04T22:54:19.000ZONEafabpb3cbt6g3oTIMESTAMP02019-04-05T05:49:07.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02014-02-06T23:01:00.000ZONEate3liesiuooycBOOLEANtrueONEazravcn5thdy6eTIMESTAMP02017-07-24T08:44:08.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa4vszwfganou76 ENTITY{"identifier":"Warner Bros. Interactive Entertainment","name":[{"value":"Warner Bros. Interactive Entertainment","locale":"es_ES"}],"external_identifier":"2655820090","description":[{"value":"Warner Bros. Interactive Entertainment","locale":"es_ES"}],"type_lookup":"461"}ONEa6dlj4i6nnmir2 ENTITY{"identifier":"Blu-ray","name":[{"value":"Blu-ray","locale":"es_ES"}],"external_identifier":"353223090","description":[{"value":"Blu-ray","locale":"es_ES"}],"type_lookup":"147","glossary":{"term":[{"value":"BluRay Disc","locale":"es_ES"}],"media_objects":[],"description":[{"value":"El nombre del formato de disco óptico de nueva generación. Blu-ray Disc (BD) ofrece cinco veces más capacidad que los DVD tradicionales. Es decir, los usuarios descubrirán toda la grandeza original de las películas y la música al sumergirse de lleno en la experiencia de la alta definición. Disfrute de largometrajes con la mejor calidad de imagen de alta definición, un brillante sonido digital multicanal y gran cantidad de extras interactivos. Blu-ray Disc también se ha diseñado para almacenar contenido digital de alta definición como vídeo, sonido, imágenes, juegos, archivos de PC y todo lo que desee. PLAYSTATION 3 incluye una unidad BD-ROM Blu-ray Disc con la que podrá ver películas de alta definición 1080p y disfrutar de lo último en juegos.","locale":"es_ES"}],"identifier":"15821","name":[{"value":"BLURAY_DISC","locale":"es_ES"}],"external_identifier":"598446054"}}MANYaid666aq2taeu2 ENTITY {"identifier":"7+","name":[{"value":"7+","locale":"es_ES"}],"external_identifier":"352515090","description":[{"value":"7+","locale":"es_ES"}],"type_lookup":"468","glossary":{"term":[{"value":"PEGI +7","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20110607/___15405O2.jpg","size":"small"}],"description":[{"value":"Los juegos marcados con este PEGI sólo será adecuado para quienes tengan 7 o más años de edad","locale":"es_ES"}],"identifier":"15405","name":[{"value":"PEGI_+7","locale":"es_ES"}],"external_identifier":"598415054"}}MANYaiz26li3o6ckzi ENTITY{"identifier":"Aventura","name":[{"value":"Aventura","locale":"es_ES"}],"external_identifier":"351978090","description":[{"value":"Aventura","locale":"es_ES"}],"type_lookup":"464"}MANYapkjfs6k2ngtfm ENTITY{"identifier":"Playstation 3","name":[{"value":"Playstation 3","locale":"es_ES"}],"external_identifier":"351431090","description":[{"value":"Playstation 3","locale":"es_ES"}],"type_lookup":"462"}ONEaqxgozunrip354 ENTITY{"identifier":"TT Games","name":[{"value":"TT Games","locale":"es_ES"}],"external_identifier":"492132090","description":[{"value":"TT Games","locale":"es_ES"}],"type_lookup":"460"}MANYauv6rouloy4tgg ENTITY{"identifier":"Aventura en 3ª persona","name":[{"value":"Aventura en 3ª persona","locale":"es_ES"}],"external_identifier":"390901090","description":[{"value":"Aventura en 3ª persona","locale":"es_ES"}],"type_lookup":"470"}Videojuegos_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000105416598"2014-02-06T23:01Z(2019-04-05T05:49:07Z(2019-04-04T22:54:19Z$001097575532151 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hce3892c8-b64b-40b2-9882-30a49d7b4892 DELETE<2023-09-02T17:15:13.764858617Z4dataloader-mongo-kafka-job62023-09-02T17:15:21.161902Z(mixer-gtin-agr-kfreeH8e3569d1-94d3-462c-8b73-0a8aee7ab2ed62023-09-02T17:15:22.531457Z,mixer-gtin-calc-pcsflmH9eb5dc9b-0b23-4ba4-85ad-1a7ac7444a5e62023-09-02T17:15:30.410185Z,mixer-gtin-calc-pcsflmHf1afed15-8c83-4d38-83b6-0536635ffc7062023-09-03T02:43:03.499978Z0mixer-product-calc-kfreeHb8df04de-5140-41f3-a294-5dcb34cbb328<2024-01-19T11:18:08.354030012Z$mixer-xsell-mixtriH72465bd4-792d-414e-8e59-e46257f6af4962024-01-19T11:18:08.404234Z4mixer-packing-units-mixtriH9225a386-6722-4d4b-9158-10389f92305e62024-01-19T11:18:28.546442Z.mixer-offer-badge-mixbiH3d339033-d3ee-4f44-b6c8-aa57636a641762024-01-19T11:21:27.596987Z.mixer-offer-badge-mixbiH02281534-640a-4149-8146-3d0434bb8c1d8ǢcIVA02IGIC91 +4842700102023-02-22T12:16:58.505Z099225558961001182COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001099218248427008&includeAsWebNovelty +es_ESNovedadDVD"2018-04-23T22:00Z5052506744815 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0"2018-06-11T23:01Z +es_ESMARCAS VARIAS +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0005052506744815$000001465493800008TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401679231944292463056HACKETT +es_ESHackett +es_ESSudaderas999.39089923013 +es_ESSudaderas +1.000 +es_ESRopa Deportiva999.39089917013 +es_ESRopa Deportiva +3.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN +es_ESRopa deportiva999.2680954013 +es_ESRopa deportiva +3.000 +es_ES$Niño (1-16 años)999.2680820013 +es_ES$Niño (1-16 años) +3.000 +es_ES2014 Infantil999.2680809013 +es_ESInfantil +3.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A263079215203991600438622 +es_ESHACKETT LIMITEDCALLE CR LAUREA MIRO,403-08980 SANT FELIU LLOBREGAT - BARCELONA (ESPAñA)  +es_ESZSudadera de niño Hackett en azul con capucha +es_ESSudadera en color azul marino, de manga larga y capucha. Tiene el cierre en el delantero mediante cremallera, dos bolsillos y print a contraste.A26307921292463056HACKETT +es_ESHACKETT5203991600438622 +es_ESHACKETT LIMITEDCALLE CR LAUREA MIRO,403-08980 SANT FELIU LLOBREGAT - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeHK580454 +es_ESZSudadera de niño Hackett en azul con capucha +es_ESZSudadera de niño Hackett en azul con capucha +es_ESSudadera en color azul marino, de manga larga y capucha. Tiene el cierre en el delantero mediante cremallera, dos bolsillos y print a contraste. +calificacion1Acalificacion2Acalificacion3RRcalificacion4VVcalificacion5VV004794140908 Años +es_ES8 AñosE +es_ESEspañol190400550907-8 +es_ES7-818171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A115","name":[{"value":"A115","locale":"es_ES"}],"external_identifier":"24400028090","description":[{"value":"Despublicación por CSO (Control Stock Online)","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02019-04-02T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-04-03T22:00:00.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02018-06-08T22:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEac5swxsdtmjapu ENTITY{"identifier":"Sudaderas","name":[{"value":"Sudaderas","locale":"es_ES"}],"external_identifier":"347714090","description":[{"value":"Sudaderas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Ropa deportiva","name":[{"value":"Ropa deportiva","locale":"es_ES"}],"external_identifier":"392135090","description":[{"value":"Ropa deportiva","locale":"es_ES"}],"type_lookup":"1599"}MANYahf5j6s6ih6wmu ENTITY{"color_code":"Azul","color_description":[{"value":"Azul","locale":"es_ES"}],"glossary":{"term":[{"value":"Color Azul","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png","size":"small"}],"description":[{"value":"Azul","locale":"es_ES"}],"identifier":"15915","name":[{"value":"COLOR_AZUL","locale":"es_ES"}],"external_identifier":"598455054"},"identifier":"Azul","name":[{"value":"Azul","locale":"es_ES"}],"external_identifier":"347189090"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2018Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001465493800008"2018-06-08T22:00Z"2019-04-03T22:00Z"2019-04-02T22:00Z$001099218248427008001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore008Hb1dd273f-8cbd-48dd-9427-ffc52895c2ba DELETE<2023-09-02T17:15:45.761717951Z4dataloader-mongo-kafka-job62023-09-02T17:15:54.946769Z(mixer-gtin-agr-kfreeH31ae5cd7-6acc-4159-8557-81c9619b00a962023-09-02T17:16:01.518355Z,mixer-gtin-calc-pcsflmHacfd00ab-b5f0-47bb-87b9-a0ab6429c2d562023-09-02T17:16:03.320057Z,mixer-gtin-calc-pcsflmH7f03681d-49d8-44c4-b299-ba83f3dbf07862023-09-03T02:43:28.772630Z0mixer-product-calc-kfreeH68c56066-1177-4574-92c9-1bc99adccaf1<2024-01-19T11:18:08.447060104Z$mixer-xsell-mixtriH72eef630-d0d2-43cf-a5ef-f274fea9c6f462024-01-19T11:18:08.679451Z4mixer-packing-units-mixtriH80e463e3-3d2f-4d07-957b-9af6fbfdd15462024-01-19T11:18:28.549784Z.mixer-offer-badge-mixbiHe56f52d0-d42c-4592-88fb-7c4c94ca5e9262024-01-19T11:21:27.598843Z.mixer-offer-badge-mixbiH7f3b4168-3772-4968-a4da-ffcdea18191c8Ǣcn +$+ +}&Loffer(A42407822).publish_ends_extendedIVA02IGIC91 +00174001088241870214001105(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001088210500174003&includeAsWebNovelty +es_ESNovedadDVD"2022-01-11T23:00Z8719855836239 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2022-03-11T15:12:29Z +es_ESPANTALONES155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008719855836239$000001524287960003TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401824442997883743056$CALVIN KLEIN JEANS +es_ES$Calvin Klein Jeans +es_ES$Pantalones joggers999.39089857013 +es_ES$Pantalones joggers +3.000 +es_ESPantalones999.39072573013 +es_ESPantalones +9.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42407822 +es_ES$Pantalones joggers999.39089857013 +es_ES$Pantalones joggers +3.000 +es_ESPantalones999.39072573013 +es_ESPantalones +9.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNNN0065383 +es_ES6PVH STORES SPAIN MODA, S.L. +es_ESPantalón de felpa de hombre con cintura elástica con cordón y ajuste regular +es_ESPantalón de felpa de algodón, ajuste regular, cintura elástica con cordón, puños de canalé , bolsillos con ranura, bolsillo trasero, detalle de costuras a lo largo de las piernas, logo con monograma de Calvin Klein en la cadera.Regular FitLigeramente estrechos pero confortables. Caja y ancho de pierna estilizados, corte reducido en el tobillo. (Medida de pantalón a la altura del tobillo 41 cm) +pt_PTRegular FitLevemente estreitos, mas confortáveis. Anca e largura da perna estilizadas, corte ajustado no tornozelo. (Comprimento das calças à altura do tornozelo: 41 cm).A42407822883743056CALVIN KLEIN +es_ESCALVIN KLEIN0065383 +es_ES6PVH STORES SPAIN MODA, S.L.998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeJ30J3199310GK +es_ESPantalón de felpa de hombre con cintura elástica con cordón y ajuste regular +es_ESPantalón de felpa de hombre con cintura elástica con cordón y ajuste regular +es_ESPantalón de felpa de algodón, ajuste regular, cintura elástica con cordón, puños de canalé , bolsillos con ranura, bolsillo trasero, detalle de costuras a lo largo de las piernas, logo con monograma de Calvin Klein en la cadera.Regular FitLigeramente estrechos pero confortables. Caja y ancho de pierna estilizados, corte reducido en el tobillo. (Medida de pantalón a la altura del tobillo 41 cm) +pt_PTRegular FitLevemente estreitos, mas confortáveis. Anca e largura da perna estilizadas, corte ajustado no tornozelo. (Comprimento das calças à altura do tornozelo: 41 cm). calificacion1Acalificacion2Acalificacion3M1calificacion4VVcalificacion5AAcalificacion62100N4792230903 +es_ES3E +es_ESEspañol479439090M +es_ESM18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-03-12T01:15:23.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-09T00:16:07.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-12T01:15:23.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYa5r36nvug7ald6 ENTITY{"identifier":"Regular","name":[{"value":"Regular","locale":"es_ES"}],"external_identifier":"8739017090","description":[{"value":"Regular","locale":"es_ES"}],"type_lookup":"1594"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pantalones de chándal","name":[{"value":"Pantalones de chándal","locale":"es_ES"}],"external_identifier":"2696298090","description":[{"value":"Pantalones de chándal","locale":"es_ES"}],"type_lookup":"1617"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Sport","name":[{"value":"Sport","locale":"es_ES"}],"external_identifier":"347623090","description":[{"value":"Sport","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001524287960003(2022-03-12T01:15:23Z(2022-08-09T00:16:07Z(2022-03-12T01:15:23Z$001088210500174003001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore00308H76eea0de-a452-4a73-a972-86c45569720b DELETE<2023-09-02T17:11:28.858053333Z4dataloader-mongo-kafka-job62023-09-02T17:11:41.206071Z(mixer-gtin-agr-kfreeH3dc6da51-5b66-4ba4-969f-152c75e595ee62023-09-02T17:11:50.032891Z,mixer-gtin-calc-pcsflmH9437aedb-1279-44e8-9665-1b8ba33dc3fa62023-09-02T17:12:01.230045Z,mixer-gtin-calc-pcsflmHee6e30f8-dc46-4f37-8511-c4b9d8b7cfca62023-09-03T02:29:43.893301Z0mixer-product-calc-kfreeH42a1e274-1d80-4113-b2ed-8c0a923c8d1b<2024-01-19T11:18:27.525671854Z$mixer-xsell-mixtriHfd30e567-e7fd-468b-a70f-b972a19eb93962024-01-19T11:18:28.030991Z4mixer-packing-units-mixtriH7208e0da-e924-4061-834d-3584b3e93a0262024-01-19T11:18:28.613612Z.mixer-offer-badge-mixbiHa7fa3664-3281-469b-b239-5e0ef6bd7c1262024-01-19T11:21:27.599665Z.mixer-offer-badge-mixbiHfd0da76f-5cc1-4cd7-ab2b-45c0f4815ab18ǢcLoffer(A45202176).publish_ends_extendedIVA02IGIC91 +07461001008443899043001705VPR +es_ESVPRCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001008470507461036&includeAsWebNovelty +es_ESNovedadDVD"2022-09-20T22:00Z8435393590654Blancos +es_ESBlancosBlancos +es_ESBlancosBlanco / Azul +es_ESBlanco / Azul115864090 +es_ESBlanco / Azul599614054 +45659 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/23/___45659O1.png +es_ES"COLOR_BLANCO/AZUL +es_ES"Color Blanco/AzulBlanco / Azul +es_ESBlanco / Azul0(2022-10-03T15:18:49Z +es_ESCHAQUETA ISORA26 +es_ESVPR274981090VPR395ML +es_ESml +0.0008435393590654$000001536055240036TRADICIONAL +es_ES"COLOR_BLANCO/AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/23/___45659O1.png2401852646336225694056DROP SHOT +es_ESDrop shot +es_ES +Mujer999.17508201013 +es_ES +Mujer +2.000 +es_ESRopa999.52157013 +es_ESRopa +7.000 +es_ES Pádel999.53765013 +es_ES Pádel 23.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESDDeportes - Contenedor rebajas OI22997.44869638011 +es_ESDDeportes - Contenedor rebajas OI22N +es_ESChaquetas999.14619964013 +es_ESChaquetas +9.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESRopa deportiva997.40963448011 +es_ESRopa deportiva +3.000 +es_ESDeportes997.40925048011 +es_ESDeportes 11.000 +es_ES$Cross - Feliz 2023997.40925036011 +es_ESFeliz 2023CDNN +es_ESRopa997.41016314011 +es_ESRopa +3.000 +es_ESPádel y tenis997.40963462011 +es_ESPádel y tenis 15.000 +es_ESDeportes997.40925048011 +es_ESDeportes 11.000 +es_ES$Cross - Feliz 2023997.40925036011 +es_ESFeliz 2023CDNNN +es_ESPDeportes - Contenedor 2as Rebajas OI2223997.45082266011 +es_ES:Contenedor 2as Rebajas OI2223N26 +es_ESVPR274981090VPR395A45202176 +es_ES +Mujer999.17508201013 +es_ES +Mujer +2.000 +es_ESRopa999.52157013 +es_ESRopa +7.000 +es_ES Pádel999.53765013 +es_ES Pádel 23.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN5347071600665992 +es_ESDROP SHOT SLCALLE MODENA, 36 PG. INDL. EUROPOLIS,..-28230 LAS ROZAS - MADRID (ESPAñA)  +es_ESBChaqueta de mujer Isora Drop Shot +es_ESCombate el frio con estilo con Chaqueta Drop Shot Isora que encontraras en la nueva colección otoño-invierno; se trata de un modelo de calidad sublime, gran confort y estilo propio. La Chaqueta Drop Shot Isora, busca convertirse en la compañera ideal de las jugadoras de pádel más exigentes con su textil; dentro y fuera de la pista. Se trata de la prenda perfecta para resistir el frio de forma cómoda y confortable. Ha sido ideada para rendir siempre al máximo nivel y, para ello, cuenta con una composición de alta calidad compuesta por fibras de Polyester Elastane Brushed, un material que permite aislar del frío durante la práctica deportiva y otorga una amplia libertad de movimientos en el rectángulo. Además en cuanto a su diseño es destacable mencionar que esta prenda se ha fabricado utilizando costuras planas, lo que proporciona mayor comodidad a la jugadora, y su cremallera viene oculta. Esta prenda cuenta con algunos avances tecnológicos como los sistemas Dry System Keepcool para garantizar un cuerpo libre de humedad y el Elasticity System que optimiza la elasticidad de la prenda ampliando la libertad de movimientos sin perder un ápice de su composición natural. La Chaqueta Drop Shot Isora busca resaltar la personalidad de todas aquellas Mujeres deportistas y competitivas que disfrutan del pádel. La prenda luce un degradado en tonos azules y blancos que reserva un espacio a los detalles azules de las cremalleras, y el logo y nombre de la marca impreso en silicona 3D. Drop Shot se define como innovación, vanguardia y desarrollo. Entendemos el concepto de negocio como una oportunidad para mejorar y estar a la altura de las expectativas de nuestros clientes. Algunas de las tecnologías incorporadas a nuestros procesos de producción textil son: Dry System Keepcool: mejoramos la evacuación de la humedad y el sudor manteniendo el cuerpo seco, en todo momento. Elasticity System: aumentamos la libertad de movimientos gracias a la elasticidad extra que compone nuestras prendas.A45202176225694056DROP SHOT +es_ESDROP SHOT5347071600665992 +es_ESDROP SHOT SLCALLE MODENA, 36 PG. INDL. EUROPOLIS,..-28230 LAS ROZAS - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeDT272833 +es_ESBChaqueta de mujer Isora Drop Shot +es_ESBChaqueta de mujer Isora Drop Shot +es_ESCombate el frio con estilo con Chaqueta Drop Shot Isora que encontraras en la nueva colección otoño-invierno; se trata de un modelo de calidad sublime, gran confort y estilo propio. La Chaqueta Drop Shot Isora, busca convertirse en la compañera ideal de las jugadoras de pádel más exigentes con su textil; dentro y fuera de la pista. Se trata de la prenda perfecta para resistir el frio de forma cómoda y confortable. Ha sido ideada para rendir siempre al máximo nivel y, para ello, cuenta con una composición de alta calidad compuesta por fibras de Polyester Elastane Brushed, un material que permite aislar del frío durante la práctica deportiva y otorga una amplia libertad de movimientos en el rectángulo. Además en cuanto a su diseño es destacable mencionar que esta prenda se ha fabricado utilizando costuras planas, lo que proporciona mayor comodidad a la jugadora, y su cremallera viene oculta. Esta prenda cuenta con algunos avances tecnológicos como los sistemas Dry System Keepcool para garantizar un cuerpo libre de humedad y el Elasticity System que optimiza la elasticidad de la prenda ampliando la libertad de movimientos sin perder un ápice de su composición natural. La Chaqueta Drop Shot Isora busca resaltar la personalidad de todas aquellas Mujeres deportistas y competitivas que disfrutan del pádel. La prenda luce un degradado en tonos azules y blancos que reserva un espacio a los detalles azules de las cremalleras, y el logo y nombre de la marca impreso en silicona 3D. Drop Shot se define como innovación, vanguardia y desarrollo. Entendemos el concepto de negocio como una oportunidad para mejorar y estar a la altura de las expectativas de nuestros clientes. Algunas de las tecnologías incorporadas a nuestros procesos de producción textil son: Dry System Keepcool: mejoramos la evacuación de la humedad y el sudor manteniendo el cuerpo seco, en todo momento. Elasticity System: aumentamos la libertad de movimientos gracias a la elasticidad extra que compone nuestras prendas. calificacion1Acalificacion2Acalificacion3E5calificacion4VVcalificacion5EPcalificacion6BA00N479448090XS +es_ESXSE +es_ESEspañol479448090XS +es_ESXS477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-24T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-25T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-09-24T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Chaquetas","name":[{"value":"Chaquetas","locale":"es_ES"}],"external_identifier":"347705090","description":[{"value":"Chaquetas","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Chaquetas","name":[{"value":"Chaquetas","locale":"es_ES"}],"external_identifier":"347862090","description":[{"value":"Chaquetas","locale":"es_ES"}],"type_lookup":"1599"}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001536055240036"2022-09-24T22:00Z"2022-09-25T22:00Z"2022-09-24T22:00Z$001008470507461036001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore03616He13742a6-ef03-4d4c-ae3a-c059e7d4e07d DELETE<2023-09-02T17:28:43.470436415Z4dataloader-mongo-kafka-job62023-09-02T17:29:17.700036Z(mixer-gtin-agr-kfreeH4185b895-b160-442f-8dc4-f8a08f86b35c62023-09-02T17:30:02.061642Z,mixer-gtin-calc-pcsflmH408a8e94-9a5c-4779-8522-ed689f4bd2de62023-09-02T17:30:02.926736Z,mixer-gtin-calc-pcsflmH5eac8eee-116b-43dd-a2bb-a9a2f4c1c7f262023-09-03T02:52:11.854661Z0mixer-product-calc-kfreeH04fc8221-b0c9-4e08-9067-63d912ba4aae<2024-01-19T11:18:27.412004622Z$mixer-xsell-mixtriHfbc145fd-2bb8-4ce6-a4c1-784187957dee62024-01-19T11:18:27.877332Z4mixer-packing-units-mixtriH60a5ec2e-d631-48e7-8259-3434560803e162024-01-19T11:18:28.617712Z.mixer-offer-badge-mixbiH332a26dd-474e-4170-9d52-a4ecb1c73c9362024-01-19T11:21:27.600614Z.mixer-offer-badge-mixbiH99f71d56-225e-482e-aa31-a51fbba90ae98ǢcLoffer(A41814753).publish_ends_extendedIVA02IGIC92 +09381001002340787540001252COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001002325209381 &includeAsWebNovelty +es_ESNovedadDVD"2021-11-23T23:00Z8435155770249Morados +es_ESMoradosMorados +es_ESMorados Morado +es_ES Morado347615090 +es_ES Morado5988330542332 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100827/___2332O1.png +es_ESCOLOR_MORADO +es_ESColor Morado Morado +es_ES Morado0(2021-11-24T10:02:11Z +es_ES(CAPA IMITACIÓN PELO158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008435155770249$000000000152174232TRADICIONAL +es_ESCOLOR_MORADO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100827/___2332O1.png24018181648438126207056DONATZELLI +es_ESDonatzelli +es_ES,Accesorios de invierno999.39072305013 +es_ES,Accesorios de invierno 28.000 +es_ESAccesorios999.39072300013 +es_ESAccesorios +4.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN +es_ESEstolas999.39072383013 +es_ESEstolas 10.000 +es_ESAccesorios999.39072300013 +es_ESAccesorios +4.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41814753 +es_ES,Accesorios de invierno999.39072305013 +es_ES,Accesorios de invierno 28.000 +es_ESAccesorios999.39072300013 +es_ESAccesorios +4.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN4840811600019778 +es_ESHGISEL DISEÑO Y MANUFACTURAS TEXTILECALLE BALMES,436(SOTANO 2-B),.-08022 BARCELONA - BARCELONA (ESPAñA)  +es_ESFEstola de pelo sintético en morado +es_ESEstola de pelo sintético en color morado con ajustable a la cintura.A418147538126207056DONATZELLI +es_ESDONATZELLI4840811600019778 +es_ESHGISEL DISEÑO Y MANUFACTURAS TEXTILECALLE BALMES,436(SOTANO 2-B),.-08022 BARCELONA - BARCELONA (ESPAñA) 998.00194 +es_ESComplementos998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos8797 +es_ESFEstola de pelo sintético en morado +es_ESFEstola de pelo sintético en morado +es_ESEstola de pelo sintético en color morado con ajustable a la cintura. +calificacion1Acalificacion2Acalificacion3E4calificacion4VVcalificacion5NSRTNpler4twpwa2rdqpeymj6wu3nmofgpaxawji3i4mkoqMANYa5wg3q7jlozdji ENTITY{"identifier":"Sintético","name":[{"value":"Sintético","locale":"es_ES"}],"external_identifier":"477968090","description":[{"value":"Sintético","locale":"es_ES"}],"type_lookup":"1633"}ONEa5wuherdryc3vm NUMBER35MANYa5xfo2abga2eme NUMBER2021ONEaa72dm3yz6vb5u ENTITY{"identifier":"Estolas","name":[{"value":"Estolas","locale":"es_ES"}],"external_identifier":"8915264090","description":[{"value":"Estolas","locale":"es_ES"}],"type_lookup":"1619"}ONEacu3nzdu3mtllm NUMBER +160.0ONEacyfplvd6an7xo STRING[{"locale":"pt_PT","value":"Liso"},{"locale":"es_ES","value":"Liso"}]ONEafbexdxymegola ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}MANYan6vk6ovojpdpu ENTITY{"identifier":"Pelo","name":[{"value":"Pelo","locale":"es_ES"}],"external_identifier":"26444204090","description":[{"value":"Pelo","locale":"es_ES"}],"type_lookup":"2501"}ONEanxumtnaxc7bmw ENTITY{"identifier":"Estolas","name":[{"value":"Estolas","locale":"es_ES"}],"external_identifier":"26709875090","description":[{"value":"Estolas","locale":"es_ES"}],"type_lookup":"1573"}MANYarbqbgl5kiiqhmCOMPLEX{"a3gd23j3lhtuz2":[{"a5shyljk4cvjq6":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"ajxlygljz2ct42":{"identifier":"Acrílico","name":[{"value":"Acrílico","locale":"es_ES"}],"external_identifier":"344750090","description":[{"value":"Acrilico","locale":"it_IT"},{"value":"Acrylic","locale":"en_GB"},{"value":"Acrílico","locale":"es_ES"},{"value":"Acrylique","locale":"fr_FR"},{"value":"Acrílico","locale":"pt_PT"}],"type_lookup":"1633"},"a23xjq2h2haw5g":100.0}],"awtfizlwej3num":{"identifier":"Exterior","name":[{"value":"Exterior","locale":"es_ES"}],"external_identifier":"477727090","description":[{"value":"Outdoor","locale":"en_GB"},{"value":"Exterior","locale":"es_ES"},{"value":"Eclairage extérieur","locale":"fr_FR"},{"value":"Exterior","locale":"pt_PT"}],"type_lookup":"1576"}}MANYaz2gbwdmqlkyim ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYazrazbd5hx4qa4 ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"} Complementos_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-10-04T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-06T05:16:02.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-10-05T06:06:28.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000152174232(2022-10-05T06:06:28Z(2022-10-06T05:16:02Z"2022-10-04T22:00Z$001002325209381 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H58d82194-3fdd-4390-a4a6-5a01d75ad13a DELETE<2023-09-02T17:30:07.139905200Z4dataloader-mongo-kafka-job62023-09-02T17:33:42.218237Z(mixer-gtin-agr-kfreeH0b9eece7-7247-4515-bdd8-29d745bd5c9b62023-09-02T17:44:50.804761Z,mixer-gtin-calc-pcsflmHdd1bd9e7-840c-4431-b313-f9397dca9f4762023-09-02T17:44:51.705723Z,mixer-gtin-calc-pcsflmH95fb300e-bc16-4d2d-9aee-fc222a690aa962023-09-03T03:02:56.730635Z0mixer-product-calc-kfreeH2ad2c3e3-a278-4f02-927f-30401c3ba910<2024-01-19T11:18:27.207307406Z$mixer-xsell-mixtriH1f117b26-e14d-4eea-9a0f-f001dd5c597162024-01-19T11:18:27.886733Z4mixer-packing-units-mixtriH73b16e4d-1d6b-441c-91c9-e315ebcc4b0e62024-01-19T11:18:28.618666Z.mixer-offer-badge-mixbiHdeaac446-1134-443e-ae3d-eab06e05ac1e62024-01-19T11:21:27.601269Z.mixer-offer-badge-mixbiHff9e7557-3d30-4be6-ac84-6c81f3b98d4d8ǢcIVA08IGIC90"2011-03-31T22:00Z +0436300102023-03-21T03:20:30.975Z0065987510001130COMPRA EN FIRME +es_ESCOMPRA EN FIRME*LECTURAS RECOMENDADAS +es_ES*LECTURAS RECOMENDADASSTERLING +es_ESSTERLING$001006513004363 "2011-03-31T22:00Z2065130043639"2011-03-31T22:00Z97819061222700(2011-09-03T02:37:18Z +es_ES Libros274977090 Libros3959781906122270$0000000001007064372401383206726896130056$MERLIN UNWIN BOOKS +es_ES$MERLIN UNWIN BOOKS +es_ESTauromaquia999.54351013 +es_ESTauromaquia 15.000 +es_ES*Ocio y Estilo de vida999.54339013 +es_ES*Ocio y Estilo de vida 42.000 +es_ES Libros999.54302013 +es_ES LibrosNNN +es_ES Libros274977090 Libros395A36680325761321602205005 +es_ES$MERLIN UNWIN BOOKS ,- - ()  +es_ESLHow to watch a bullfight (Tapa blanda) +es_ESA gran parte de los que presencian la corrida en una plaza de toros y a muchísimos de los que la contemplan a través de la televisión les resulta difícil comprender cabalmente el fascinante espectáculo que se desarrolla ante sus ojos: para saber de toros no basta con haber asistido a muchas corridas, también es necesario saber lo que se ve. Manual de tauromaquia para nuevos aficionados.A36680324954941600130799 +es_ES@EGARTORRE S.L. - ADMON.CONCURSALCALLE PRIMAVERA(PG IND EL MALVAR),2,NV31-28500 ARGANDA DEL REY - MADRID (ESPAñA) 998.00070 +es_ES Libros998.00069 +es_ES Libros998 +es_ES@Jerarquía de Ficha de Productos9781906122270 +es_ESLHow to watch a bullfight (Tapa blanda) +es_ESLHow to watch a bullfight (Tapa blanda) +es_ESA gran parte de los que presencian la corrida en una plaza de toros y a muchísimos de los que la contemplan a través de la televisión les resulta difícil comprender cabalmente el fascinante espectáculo que se desarrolla ante sus ojos: para saber de toros no basta con haber asistido a muchas corridas, también es necesario saber lo que se ve. Manual de tauromaquia para nuevos aficionados. +calificacion1Acalificacion2Acalificacion3E5calificacion4VVcalificacion5AC00pler4twpwa2rdqpkcwmvhkxxd52gpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02014-10-28T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02014-10-29T23:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02011-03-31T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE*ONEa3a2qz2bn5caz6 ENTITY{"identifier":"Abril","name":[{"value":"Abril","locale":"es_ES"}],"external_identifier":"347512090","description":[{"value":"Abril","locale":"es_ES"}],"type_lookup":"1050"}MANYa3aauuktnvama2 ENTITY{"identifier":"0127534","name":[{"value":"WOOD, TRISTAN","locale":"es_ES"}],"external_identifier":"460757051","given_name":"TRISTAN","family_name":"WOOD","birth_place":[],"death_place":[],"biography":[],"media_objects":[],"normalized_name":"tristan-wood"}ONEa3novp2ls57ixm STRINGT[{"locale":"es_ES","value":"TAUROMAQUIA"}]ONEa4pp5rqvfzxxf6 NUMBER24ONEa5ej6iwjweshes STRING000ONEa6vetl5kp4q3rc ENTITY{"identifier":"Publicado","name":[{"value":"Publicado","locale":"es_ES"}],"external_identifier":"351272090","description":[{"value":"Publicado","locale":"es_ES"}],"type_lookup":"417"}ONEabrulnhj2sxpbm ENTITY{"identifier":"Tapa blanda","name":[{"value":"Tapa blanda","locale":"es_ES"}],"external_identifier":"9651455090","description":[{"value":"Tapa blanda","locale":"es_ES"}],"type_lookup":"420"}ONEacnblp3uq557wk STRING019ONEadwyeen33wnwra STRING004ONEaitc57dwo6e7iqBOOLEAN +falseONEaj6qadcmhrezii NUMBER217ONEangal4rqdmxpse STRINGd[{"locale":"es_ES","value":"OCIO Y TIEMPO LIBRE"}]ONEaogwgan32v4m66 STRINGAGMANYaoyr2i73cpmiu6 ENTITY{"identifier":"Inglés","name":[{"value":"Inglés","locale":"es_ES"}],"external_identifier":"347433090","description":[{"value":"Inglés","locale":"es_ES"}],"type_lookup":"157"}ONEaps33pgkahzbpe NUMBER1MANYavavneorwb4aq4 ENTITY{"identifier":"Color","name":[{"value":"Color","locale":"es_ES"}],"external_identifier":"347472090","description":[{"value":"Color","locale":"es_ES"}],"type_lookup":"1010"}ONEavl7kh42fi2dm4 NUMBER19MANYavmuqs346a7gxm ENTITY{"identifier":"Tapa blanda","name":[{"value":"Tapa blanda","locale":"es_ES"}],"external_identifier":"10121051090","description":[{"value":"Tapa blanda","locale":"es_ES"}],"type_lookup":"418"}ONEawxedxihgayc72 NUMBER2011ONEay5m4egk42mrno ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}MANY*libros_iss_calculatedCOMPLEX{"name":"WOOD, TRISTAN","rol":"Autor","grouper":"author","normalize_name_grouper":"author|tristan-wood"}Libros_ISS.SPEC_SECONDARY_TEMPLATEaños +es_ESaños 18.000años +es_ESaños999.000 +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000100706437"2011-03-31T22:00Z"2014-10-29T23:00Z"2014-10-28T23:00Z$001006513004363 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H0031ceba-dfb4-4ad0-aad6-973815b76471 DELETE<2023-09-02T17:23:20.456110601Z4dataloader-mongo-kafka-job62023-09-02T17:23:33.597943Z(mixer-gtin-agr-kfreeH051b156a-24c6-4bc6-bb44-03072328d93e62023-09-02T17:23:52.115982Z,mixer-gtin-calc-pcsflmH61af97f8-025c-44cf-b346-4756dd40fdac62023-09-02T17:23:54.215314Z,mixer-gtin-calc-pcsflmHed1661c8-e7ec-4e49-b7b7-fb154055d5eb62023-09-03T02:50:21.671988Z0mixer-product-calc-kfreeH20559764-3c26-4e63-a1b7-768c08e4981e<2024-01-19T11:18:08.707021195Z$mixer-xsell-mixtriH40db765c-b488-4d21-b5d0-e1dce07c804d62024-01-19T11:18:08.792264Z4mixer-packing-units-mixtriHf4f2316d-efac-4d82-8bb4-3d9afcde4ebd62024-01-19T11:18:28.751404Z.mixer-offer-badge-mixbiHf6d2c845-e89f-4e0c-aec9-bb3f44bf06fd62024-01-19T11:21:27.603760Z.mixer-offer-badge-mixbiH1a15b2dd-24f9-4cbb-abe5-db8c01815c208ǢcLoffer(A40253262).publish_ends_extendedIVA02IGIC91 +23386001006639569399001254COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001006625423386 &includeAsWebNovelty +es_ESNovedadDVD"2021-06-30T22:00Z8412688453627 Negros +es_ES Negros Negros +es_ES Negros0(2021-07-05T13:09:08Z +es_ES*MOCHILA DOBLE CON CAN56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008412688453627$0000000001515373872401803064332200070056 +SAFTA +es_ES +Safta +es_ES"Mochilas Infantil999.20046730013 +es_ESMochilas +1.000 +es_ES&2 Mochilas Infantil999.20046726013 +es_ES"Mochilas Infantil +2.000 +es_ES"Mochilas y carros999.7576918013 +es_ES"Mochilas y carros +1.000 +es_ESPapelería999.54253013 +es_ESPapeleríaNNNN56 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40253262 +es_ES"Mochilas Infantil999.20046730013 +es_ESMochilas +1.000 +es_ES&2 Mochilas Infantil999.20046726013 +es_ES"Mochilas Infantil +2.000 +es_ES"Mochilas y carros999.7576918013 +es_ES"Mochilas y carros +1.000 +es_ESPapelería999.54253013 +es_ESPapeleríaNNNN4929011600105767 +es_ESSAFTA S.A.CALLE POL. IND. LAS TRECE ROSAS,2-46970 ALAQUAS - VALENCIA (ESPAñA)  +es_ESMochila Doble con Cantoneras Adaptable a Carro Reciclable. BLACKFIT8 "TOPOGRAPHY" Safta Negra +es_ESMochila Doble con Cantoneras Adaptable a Carro Reciclable. BLACKFIT8 "TOPOGRAPHY" Safta Negra.Cantoneras de goma antirozaduras en ambos lados para aumentar la durabilidad (PATENTADO SAFTA). Adaptable a Carro Portamochilas. Dos departamentos Grandes con cremallera. Doble bolsillo frontal con organizador interior. Bolsillo lateral portabotellas. Doble tirador en cremalleras principales para facilitar su apertura. Hombreras y espalda ergonómicas y acolchadas. Asa de mano forrada en la parte superior.A40253262200070056 +SAFTA +es_ES +SAFTA4929011600105767 +es_ESSAFTA S.A.CALLE POL. IND. LAS TRECE ROSAS,2-46970 ALAQUAS - VALENCIA (ESPAñA) 998.00117 +es_ESPapelería998.00116 +es_ESPapelería998 +es_ES@Jerarquía de Ficha de Productos +es_ESBlackFit834885469090BlackFit8 +es_ESBlackFit8850682142773 +es_ESMochila Doble con Cantoneras Adaptable a Carro Reciclable. BLACKFIT8 "TOPOGRAPHY" Safta Negra +es_ESMochila Doble con Cantoneras Adaptable a Carro Reciclable. BLACKFIT8 "TOPOGRAPHY" Safta Negra +es_ESMochila Doble con Cantoneras Adaptable a Carro Reciclable. BLACKFIT8 "TOPOGRAPHY" Safta Negra.Cantoneras de goma antirozaduras en ambos lados para aumentar la durabilidad (PATENTADO SAFTA). Adaptable a Carro Portamochilas. Dos departamentos Grandes con cremallera. Doble bolsillo frontal con organizador interior. Bolsillo lateral portabotellas. Doble tirador en cremalleras principales para facilitar su apertura. Hombreras y espalda ergonómicas y acolchadas. Asa de mano forrada en la parte superior. +calificacion1CDcalificacion2Ecalificacion3M5calificacion4VVcalificacion5B06Npler4twpwa2rdqpflvz4jlffiqggONEa6o262gskfqnh6 NUMBER42ONEa6oeh47hjntrpm ENTITY{"identifier":"kg","name":[{"value":"kg","locale":"es_ES"}],"external_identifier":"348777090","description":[{"value":"kg","locale":"es_ES"}],"type_lookup":"206"}MANYaajv2ni5ywcxew ENTITY{"identifier":"Poliéster 300D","name":[{"value":"Poliéster 300D","locale":"es_ES"}],"external_identifier":"12030833090","description":[{"value":"Poliéster 300D","locale":"es_ES"}],"type_lookup":"194"}ONEad7oxvchkqzgww NUMBER0.84ONEaduc37m2qzz2im NUMBER32ONEafackaxec66kas ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}ONEahab3c3echl6lq ENTITY{"identifier":"Mochilas Infantil","name":[{"value":"Mochilas Infantil","locale":"es_ES"}],"external_identifier":"20955632090","description":[{"value":"Mochilas Infantil","locale":"es_ES"}],"type_lookup":"800"}ONEaol4hwxrsk7n6s NUMBER15Papeleria_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02022-09-23T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-26T03:11:05.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02018-07-04T22:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESVoluminoso348625090Voluminoso +es_ESVoluminoso401$000000000151537387"2018-07-04T22:00Z(2022-09-26T03:11:05Z"2022-09-23T22:00Z$001006625423386 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H21cd1026-4141-411c-a72b-5e2926274112 DELETE<2023-09-02T17:26:26.320645888Z4dataloader-mongo-kafka-job62023-09-02T17:26:39.850373Z(mixer-gtin-agr-kfreeHcae70543-69f0-4cc5-a431-305b4de8b69862023-09-02T17:26:47.615413Z,mixer-gtin-calc-pcsflmHeaae5ec6-bc95-4906-a7e3-9412225728cd62023-09-02T17:26:48.747167Z,mixer-gtin-calc-pcsflmH0a298e09-aceb-4702-a468-23caa0973cad62023-09-03T02:48:26.274922Z0mixer-product-calc-kfreeHb027cef0-8499-4ec0-aae8-38cc0545be29<2024-01-19T11:18:08.970934412Z$mixer-xsell-mixtriHc8361ab7-064b-4610-8784-fb61d0efcfaf62024-01-19T11:18:09.034749Z4mixer-packing-units-mixtriH882753c5-173b-4a54-aa61-80457b5858bf62024-01-19T11:18:28.759770Z.mixer-offer-badge-mixbiH27dccf13-51ef-4c19-88a1-c539a9737c8e62024-01-19T11:21:27.605017Z.mixer-offer-badge-mixbiH1d3bf678-0fe7-4586-8f35-967ee7704e5a8ǢcLoffer(A41242540).publish_ends_extendedIVA02IGIC91 +27958001099240623396001187COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001099218727958008&includeAsWebNovelty +es_ESNovedadDVD"2021-09-26T22:00Z0196012060900 +Rojos +es_ES +Rojos +Rojos +es_ES +RojosRojo +es_ESRojo344736090 +es_ESRojo599025054 +25344 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___25344O3.png +es_ESCOLO_ROJO +es_ESColo RojoRojo +es_ESRojo0(2021-11-03T14:10:06Z +es_ESCAMISETA156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000196012060900$000001518879440008TRADICIONAL +es_ESCOLO_ROJO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___25344O3.png2401812609241896471056NAPAPIJRImarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/05/19/2/00001305192/00001305192784mM1011.jpg +es_ESNapapijri +es_ESCamisetas999.39089905013 +es_ESCamisetas +4.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41242540 +es_ESCamisetas999.39089905013 +es_ESCamisetas +4.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNN6236071600538405 +es_ES4VF APPAREL ESPAÑA, S.L.U.CALLE JOAN MIRO,19-21.PLANTA BAJA,.-08005 BARCELONA - BARCELONA (ESPAñA)  +es_ESdCamiseta de niño con cuello redondo y manga corta +es_ESCamiseta de manga corta con cuello redondo. Los bordes tipo canalé. Logo bordado y estampado.A41242540896471056NAPAPIJRI +es_ESNAPAPIJRI6236071600538405 +es_ES4VF APPAREL ESPAÑA, S.L.U.CALLE JOAN MIRO,19-21.PLANTA BAJA,.-08005 BARCELONA - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeNP0A4G4PR89 +es_ESdCamiseta de niño con cuello redondo y manga corta +es_ESdCamiseta de niño con cuello redondo y manga corta +es_ESCamiseta de manga corta con cuello redondo. Los bordes tipo canalé. Logo bordado y estampado. +calificacion1Acalificacion2Acalificacion3ROcalificacion4VVcalificacion5VVPDN4794140908 Años +es_ES8 AñosE +es_ESEspañol4794140908 Años +es_ES8 Años477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-13T03:08:21.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-14T03:08:21.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02021-12-11T00:42:33.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 40º","name":[{"value":"Lavar máximo 40º","locale":"es_ES"}],"external_identifier":"350583090","description":[{"value":"Lavar máximo 40º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxCuarenta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/___94922.png","size":"small"}],"description":[{"value":"Lavar Máximo 40º","locale":"es_ES"}],"identifier":"94922","name":[{"value":"LAVARMAXCUARENTA","locale":"es_ES"}],"external_identifier":"600207054"}}{"identifier":"Secadora a temperatura mínima","name":[{"value":"Secadora a temperatura mínima","locale":"es_ES"}],"external_identifier":"484903090","description":[{"value":"Secadora a temperatura mínima","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Planchado max 130º","name":[{"value":"Planchado max 130º","locale":"es_ES"}],"external_identifier":"484896090","description":[{"value":"Planchado max 130º","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"351059090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":100.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518879440008(2021-12-11T00:42:33Z(2022-09-14T03:08:21Z(2022-09-13T03:08:21Z$001099218727958008001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore008Hc0596179-a5f1-45d9-ba8a-4c1fac9d52a7 DELETE<2023-09-02T17:22:09.580312887Z4dataloader-mongo-kafka-job62023-09-02T17:22:19.482037Z(mixer-gtin-agr-kfreeH2770daeb-20d1-4d94-9078-78dc22427f4f62023-09-02T17:23:12.108632Z,mixer-gtin-calc-pcsflmH7da5099c-19f5-496b-af88-9ee586b065b462023-09-02T17:23:14.007605Z,mixer-gtin-calc-pcsflmH47e07208-5e1d-4715-8cd2-17d42fcb599a62023-09-03T02:44:15.039482Z0mixer-product-calc-kfreeH8f49b77a-bfb8-4fdb-95ec-60da4aed651c<2024-01-19T11:18:09.765940216Z$mixer-xsell-mixtriH852b4368-6bb9-41b9-998a-129342c69ee662024-01-19T11:18:09.822311Z4mixer-packing-units-mixtriHc1139e3a-0d18-4f9d-a155-96986ff4865362024-01-19T11:18:28.859036Z.mixer-offer-badge-mixbiH99a1d3e2-c921-4b26-8615-0b195ebd495762024-01-19T11:21:27.687823Z.mixer-offer-badge-mixbiHc68134ba-9882-4eaf-87f0-e1313471b69d8ǢcLoffer(A40892174).publish_ends_extendedIVA02IGIC91 +05998001052041347343001506COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001052050605998010Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2022-01-17T17:09:33Z +es_ES(PIJ P/C MINNIE TOPOS156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401809546672$000001517558610010TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png2401809546672151975056COTTON JUICE +es_ESCotton Juice +es_ESInfantil997.38839707011 +es_ESInfantil +3.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESPijamas999.39073158013 +es_ESPijamas +1.000 +es_ESPijamas999.39073155013 +es_ESPijamas +5.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40892174 +es_ESPijamas999.39073158013 +es_ESPijamas +1.000 +es_ESPijamas999.39073155013 +es_ESPijamas +5.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN0977017 +es_ESXXIAMEN HONESTY INDUSTRIALCORPORATION LIMITED +es_ES,Pijama de niña Minnie +es_ESPijama en color blanco con dibujo frontal de Minnie y pantalón corto.A40892174151975056DISNEY-DTR +es_ESDISNEY-DTR0977017 +es_ESXXIAMEN HONESTY INDUSTRIALCORPORATION LIMITED998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeL22N5403 +es_ES,Pijama de niña Minnie +es_ES,Pijama de niña Minnie +es_ESPijama en color blanco con dibujo frontal de Minnie y pantalón corto. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5VV00N47909609010 Años +es_ES10 AñosE +es_ESEspañol190400560909-10 +es_ES9-1018171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING(Fuerzo Rebajas 80822ONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-14T18:49:48.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-15T18:49:48.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-05-02T22:00:01.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pijamas","name":[{"value":"Pijamas","locale":"es_ES"}],"external_identifier":"375451090","description":[{"value":"Pijamas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niña","name":[{"value":"Niña","locale":"es_ES"}],"external_identifier":"357131090","description":[{"value":"Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pijamas","name":[{"value":"Pijamas","locale":"es_ES"}],"external_identifier":"8610839090","description":[{"value":"Pijamas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517558610010(2022-05-02T22:00:01Z(2022-09-15T18:49:48Z(2022-09-14T18:49:48Z$001052050605998010001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore010Hc9ce9a15-0185-4339-9b06-2f0cff50ca5e DELETE<2023-09-02T17:23:02.018114493Z4dataloader-mongo-kafka-job62023-09-02T17:23:12.535002Z(mixer-gtin-agr-kfreeH825a0de4-1819-4e52-8c70-1e97e87fc79562023-09-02T17:24:28.101825Z,mixer-gtin-calc-pcsflmH6617fd93-7e5d-4446-b59e-797ecd383dcb62023-09-02T17:24:31.510835Z,mixer-gtin-calc-pcsflmH1fc47a14-eabd-47ef-84d0-2dffa018d8b462023-09-03T02:50:33.771988Z0mixer-product-calc-kfreeHdd805966-1988-499c-a499-6a4b5582e2f6<2024-01-19T11:18:09.949718456Z$mixer-xsell-mixtriHdce75ee0-2689-4269-88b1-ebe47640d48662024-01-19T11:18:10.100343Z4mixer-packing-units-mixtriH51dba8d2-4e98-4d7a-a44f-3fefc7fb340462024-01-19T11:18:28.861860Z.mixer-offer-badge-mixbiHc9a86078-ca32-49a7-ab51-36a4a543ec6d62024-01-19T11:21:27.688997Z.mixer-offer-badge-mixbiH475ef0f5-4d19-4880-8cf3-db6da9d6ff178ǢcLoffer(A41268806).publish_ends_extendedIVA02IGIC91 +00360001036040345970001301COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001036030100360038&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31820072090 +es_ESEste producto cuenta con la certificación Oeko-Tex Standard 100 que garantiza que ha sido analizado para detectar cualquier sustancia nociva para la salud. Por lo tanto, este certificado asegura que este producto está libre de agentes tóxicos y cumple unos estándares respecto a los químicos usados en su proceso de fabricación.31855841054 +11935 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png +es_ESFCERTIFICACION_OEKO-TEX_STANDARD_100 +es_ESHCertificación Oeko-tex Standard 100 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/21/11935_3_.png002 +es_ESHCertificación Oeko-tex Standard 1008SUSTAINABILITY_MANUFACTURING"2021-09-28T22:00Z4056592938173Naranjas +es_ESNaranjasNaranjas +es_ESNaranjasNaranja +es_ESNaranja347412090 +es_ESNaranja596745054 +10150 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___10150O4.png +es_ESCOLOR_NARANJA +es_ESColor NaranjaNaranja +es_ESNaranja0(2021-09-29T18:30:56Z +es_ES*BRAGA BIKINI LISA COL158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004056592938173$000001518985150038TRADICIONAL +es_ESCOLOR_NARANJA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___10150O4.png24018128708562940438056MARYAN MEHLHORN +es_ESMaryan Mehlhorn +es_ES Bragas de bikini999.39089969013 +es_ES Bragas de bikini +3.000 +es_ESBikinis999.39089965013 +es_ESBikinis +8.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ES +Baño997.38153216011 +es_ES +Baño +7.000 +es_ESModa Mujer997.38150773011 +es_ESModa Mujer +5.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN001036020200279158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41268806 +es_ES Bragas de bikini999.39089969013 +es_ES Bragas de bikini +3.000 +es_ESBikinis999.39089965013 +es_ESBikinis +8.000 +es_ESRopa de Baño999.39089930013 +es_ESRopa de Baño +7.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN5965291600997452 +es_ES@TEWIS SMART SYSTEM ESPAÑA, S.L.CALLE PQ TEC.VALEN.C/GUGLIELMO MARCO,14-46980 PATERNA - VALENCIA (ESPAñA)  +es_ES8Braga bikini lisa color teja +es_ESBraga bikini lisa color teja. Moda de baño sostenible, tejido que reduce la huella humana fabricado en colaboración con empresa Eurojersey italiana.A412688062940438056MARYAN MEHLHORN +es_ESMARYAN MEHLHORN5965291600997452 +es_ES@TEWIS SMART SYSTEM ESPAÑA, S.L.CALLE PQ TEC.VALEN.C/GUGLIELMO MARCO,14-46980 PATERNA - VALENCIA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize827 +es_ES8Braga bikini lisa color teja +es_ES8Braga bikini lisa color teja +es_ESBraga bikini lisa color teja. Moda de baño sostenible, tejido que reduce la huella humana fabricado en colaboración con empresa Eurojersey italiana. +calificacion1Acalificacion2Acalificacion3HVcalificacion4VVcalificacion5AH00N038E +es_ESEspañol038477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-20T01:01:46.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-21T01:01:46.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-07-05T15:12:17.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavado Delicado","name":[{"value":"Lavado Delicado","locale":"es_ES"}],"external_identifier":"8955928090","description":[{"value":"Lavado Delicado","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Detergente neutro","name":[{"value":"Detergente neutro","locale":"es_ES"}],"external_identifier":"374957090","description":[{"value":"Detergente neutro","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No planchar","name":[{"value":"No planchar","locale":"es_ES"}],"external_identifier":"350554090","description":[{"value":"No planchar","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No Planchar","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201208/08/___840O1.png","size":"small"}],"description":[{"value":"No Planchar","locale":"es_ES"}],"identifier":"840","name":[{"value":"NO_PLANCHAR","locale":"es_ES"}],"external_identifier":"600047054"}}{"identifier":"Lavado Delicado","name":[{"value":"Lavado Delicado","locale":"es_ES"}],"external_identifier":"8955928090","description":[{"value":"Lavado Delicado","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Secado estirado a la sombra","name":[{"value":"Secado estirado a la sombra","locale":"es_ES"}],"external_identifier":"8955922090","description":[{"value":"Secado estirado a la sombra","locale":"es_ES"}],"type_lookup":"1584"}ONEa4aig6savkv75m STRING[{"locale":"pt_PT","value":"Sem fecho"},{"locale":"es_ES","value":"Sin cierre"}]MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bragas de bikini","name":[{"value":"Bragas de bikini","locale":"es_ES"}],"external_identifier":"12873128090","description":[{"value":"Bragas de bikini","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Bikinis","name":[{"value":"Bikinis","locale":"es_ES"}],"external_identifier":"8970133090","description":[{"value":"Bikinis","locale":"es_ES"}],"type_lookup":"1599"}ONEarte4uoeu4rkhe ENTITY{"identifier":"Clásicas","name":[{"value":"Clásicas","locale":"es_ES"}],"external_identifier":"22799565090","description":[{"value":"Clásicas","locale":"es_ES"}],"type_lookup":"2506"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliimida","name":[{"value":"Poliimida","locale":"es_ES"}],"external_identifier":"32198303090","description":[{"value":"Polyimide","locale":"en_GB"},{"value":"Poliimida","locale":"es_ES"},{"value":"Polyimide","locale":"fr_FR"},{"value":"Poli-imida","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":72},{"adbyfb4jfvuv5k":28,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518985150038(2022-07-05T15:12:17Z(2022-09-21T01:01:46Z(2022-09-20T01:01:46Z$001036030100360038001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore038H7a9f3b92-9763-4091-a2e1-ba740146f5d1 DELETE<2023-09-02T17:24:00.387121449Z4dataloader-mongo-kafka-job62023-09-02T17:24:09.467178Z(mixer-gtin-agr-kfreeH22fa478a-e939-4210-922e-abf5e6d288ee62023-09-02T17:25:58.304586Z,mixer-gtin-calc-pcsflmH14ebe333-af78-4441-8956-570416dddce262023-09-02T17:26:00.217611Z,mixer-gtin-calc-pcsflmH91150750-113c-487f-bbc9-ab7b2150501a62023-09-03T02:41:45.873056Z0mixer-product-calc-kfreeHccb61a7d-9967-4e0e-80e8-a7f8dc3c9b4f<2024-01-19T11:18:10.565950624Z$mixer-xsell-mixtriH3817ede6-0b2e-405d-9493-9b7455abf63b62024-01-19T11:18:10.720381Z4mixer-packing-units-mixtriH8a79653f-b908-45c9-9de9-e1aa444dba0962024-01-19T11:18:28.915174Z.mixer-offer-badge-mixbiH13d12b74-5805-45c8-a520-31f49ad216fc62024-01-19T11:21:27.692243Z.mixer-offer-badge-mixbiH02fe0757-fe79-455c-9174-a9d7894e242e8Ǣcn +$+ +}&Loffer(A40768311).publish_ends_extendedIVA02IGIC91 +08021001017342134777001410COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001017341008021006"2022-06-19T22:00Z8434816194424 Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2022-04-08T15:23:42Z +es_ES*BIKINI EST. ESTRELLAS156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008434816194424$000001517169150006TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png240180837256239212703056(KIDS EL CORTE INGLES +es_ES*Kids El Corte Inglés +es_ESBikinis999.39089407013 +es_ESBikinis +2.000 +es_ES +Baño999.39089402013 +es_ES +Baño 25.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40768311 +es_ESBikinis999.39089407013 +es_ESBikinis +2.000 +es_ES +Baño999.39089402013 +es_ES +Baño 25.000 +es_ES +Niña999.39073112013 +es_ES +Niña +1.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN0905531 +es_ESVKUNSHAN KTEX INTERNATIONAL TRADINGCO., LTD. +es_ESNBikini estampado estrellas mar de niña +es_ESPBikini estampado estrellas mar de niña.A4076831139212703056KIDS ECI +es_ESKIDS ECI0905531 +es_ESVKUNSHAN KTEX INTERNATIONAL TRADINGCO., LTD.998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeSTAR MBI +es_ESNBikini estampado estrellas mar de niña +es_ESNBikini estampado estrellas mar de niña +es_ESPBikini estampado estrellas mar de niña. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5VV00N4793890906 Años +es_ES6 AñosE +es_ESEspañol190400540905-6 +es_ES5-618171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING(Fuerzo Rebajas 80822ONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-21T00:53:35.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-22T00:53:35.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-05-02T22:00:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Estampado grande","name":[{"value":"Estampado grande","locale":"es_ES"}],"external_identifier":"25521448090","description":[{"value":"Estampado grande","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Bikinis","name":[{"value":"Bikinis","locale":"es_ES"}],"external_identifier":"349578090","description":[{"value":"Bikinis","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niña","name":[{"value":"Niña","locale":"es_ES"}],"external_identifier":"357131090","description":[{"value":"Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Baño","name":[{"value":"Baño","locale":"es_ES"}],"external_identifier":"349577090","description":[{"value":"Baño","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":15,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Elastano","name":[{"value":"Elastano","locale":"es_ES"}],"external_identifier":"347693090","description":[{"value":"Elastam","locale":"it_IT"},{"value":"Elastane","locale":"en_GB"},{"value":"Elastano","locale":"es_ES"},{"value":"Élasthanne","locale":"fr_FR"},{"value":"Elastano","locale":"pt_PT"}],"type_lookup":"1633"}},{"adbyfb4jfvuv5k":85,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliamida","name":[{"value":"Poliamida","locale":"es_ES"}],"external_identifier":"347782090","description":[{"value":"Poliammide","locale":"it_IT"},{"value":"Polyamide","locale":"en_GB"},{"value":"Poliamida","locale":"es_ES"},{"value":"Polyamide","locale":"fr_FR"},{"value":"Poliamida","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001517169150006(2022-05-02T22:00:01Z(2022-09-22T00:53:35Z(2022-09-21T00:53:35Z$001017341008021006001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore006H54839c4c-5ea0-4c54-8574-f97fe55fb1e3 DELETE<2023-09-02T17:24:51.392313200Z4dataloader-mongo-kafka-job62023-09-02T17:25:02.566856Z(mixer-gtin-agr-kfreeH2a56e6d9-9b2c-43d5-8d78-00be0021f72462023-09-02T17:26:34.121773Z,mixer-gtin-calc-pcsflmH14191853-f5d0-4a05-bd65-25c9f56c0a1d62023-09-02T17:26:34.407096Z,mixer-gtin-calc-pcsflmH32edac16-f3e5-4f8e-8e5d-d5f3039e5c0562023-09-03T02:42:29.097534Z0mixer-product-calc-kfreeH6df4f3d7-d044-4580-bbf4-bf3ec103d9c4<2024-01-19T11:18:10.872858707Z$mixer-xsell-mixtriH600b4740-c4f8-464c-b94e-e832ef28431462024-01-19T11:18:11.092249Z4mixer-packing-units-mixtriH8ae2791d-e21f-4501-94f6-0321077da96062024-01-19T11:18:28.924184Z.mixer-offer-badge-mixbiH2909c812-e351-42e6-b4e8-771995ac6e1f62024-01-19T11:21:27.693987Z.mixer-offer-badge-mixbiH91ef01da-1062-40a6-bb6d-a4e85ab015048ǢcLoffer(A41257652).publish_ends_extendedIVA02IGIC91 +03551001011940346078001111COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001011911103551002&includeAsWebNovelty +es_ESNovedadDVD +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGINMorados +es_ESMoradosMorados +es_ESMoradosLila +es_ESLila347704090 +es_ESLila596884054 +11146 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___11146O2.png +es_ESCOLOR_LILA +es_ESColor LilaLila +es_ESLila0(2021-09-29T18:33:23Z +es_ESPIJAMA CUADROS158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401812761437$000001518922900002TRADICIONAL +es_ESCOLOR_LILA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/21/___11146O2.png2401812761437126815056ENFASISmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/0S/00/0/0000000S000/0000000S000550mM1011.jpg +es_ESÉnfasis +es_ES"Pijamas completos999.39072770013 +es_ES"Pijamas completos +1.000 +es_ESPijamas999.39072769013 +es_ESPijamas 13.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41257652 +es_ES"Pijamas completos999.39072770013 +es_ES"Pijamas completos +1.000 +es_ESPijamas999.39072769013 +es_ESPijamas 13.000 +es_ESLencería999.39072733013 +es_ESLencería +6.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN0905254 +es_ESALPINE OVERSEAS +es_ESLPijama de mujer de cuadros manga corta +es_EShPijama de cuadros con manga corta y pantalón largo.A41257652126815056ENFASIS +es_ESENFASIS12605991600905254 +es_ESALPINE OVERSEAS~CALLE 438, UDYOG VIHAR PHASE-III,,.-122006 GURUGRAM - (INDIA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeS22L/EFESPR2341 +es_ESLPijama de mujer de cuadros manga corta +es_ESLPijama de mujer de cuadros manga corta +es_EShPijama de cuadros con manga corta y pantalón largo. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AH00N47925309036 +es_ES36E +es_ESEspañol479448090XS +es_ESXS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-27T01:07:32.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-28T01:07:32.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-03-06T05:04:38.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}ONEa4aig6savkv75m STRING[{"locale":"en_GB","value":"No clasp"},{"locale":"fr_FR","value":"Sans fermoir"},{"locale":"pt_PT","value":"Sem fecho"},{"locale":"es_ES","value":"Sin cierre"}]MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Cuadros","name":[{"value":"Cuadros","locale":"es_ES"}],"external_identifier":"2655615090","description":[{"value":"Cuadros","locale":"es_ES"}],"type_lookup":"2504"}ONEabf2vvifj26pzi ENTITY{"identifier":"Largo","name":[{"value":"Largo","locale":"es_ES"}],"external_identifier":"2655628090","description":[{"value":"Largo","locale":"es_ES"}],"type_lookup":"2507"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pijamas completos","name":[{"value":"Pijamas completos","locale":"es_ES"}],"external_identifier":"12873143090","description":[{"value":"Pijamas completos","locale":"es_ES"}],"type_lookup":"1617"}MANYadjgpxmrhwndvq ENTITY{"identifier":"Esencial","name":[{"value":"Esencial","locale":"es_ES"}],"external_identifier":"40113427090","description":[{"value":"Esencial","locale":"es_ES"}],"type_lookup":"1579"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pijamas","name":[{"value":"Pijamas","locale":"es_ES"}],"external_identifier":"8610839090","description":[{"value":"Pijamas","locale":"es_ES"}],"type_lookup":"1599"}ONEastcg34k65osv2 STRING[{"locale":"en_GB","value":"Into the Provence"},{"locale":"fr_FR","value":"Into The Provence"},{"locale":"pt_PT","value":"Into The Provence"},{"locale":"es_ES","value":"Into The Provence"}]MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":100.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518922900002(2022-03-06T05:04:38Z(2022-09-28T01:07:32Z(2022-09-27T01:07:32Z$001011911103551002001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore002Hc0c4d293-51eb-461b-a303-5b18c02261df DELETE<2023-09-02T17:28:41.787089604Z4dataloader-mongo-kafka-job62023-09-02T17:29:20.064579Z(mixer-gtin-agr-kfreeH945690fe-6fb1-4547-9ada-52d5a8d751b362023-09-02T17:29:46.121708Z,mixer-gtin-calc-pcsflmH654d80cd-1128-4510-b958-d7c78ff2193362023-09-02T17:29:48.413760Z,mixer-gtin-calc-pcsflmH7af0c4da-ee6e-477e-8bbe-a848915ac37f62023-09-03T02:51:51.833005Z0mixer-product-calc-kfreeH1862af5b-b7ae-46bb-958f-31255fc9e87f<2024-01-19T11:18:11.468766154Z$mixer-xsell-mixtriH08854c6c-2d1a-4062-a667-eb0f7b60c7c862024-01-19T11:18:11.607780Z4mixer-packing-units-mixtriH3054fc80-e015-4f35-9692-a9835860e1cd62024-01-19T11:18:29.008744Z.mixer-offer-badge-mixbiH21674a82-17dc-4b94-ab55-a8aa9373ea5962024-01-19T11:21:27.697783Z.mixer-offer-badge-mixbiHabb2b919-b09b-458b-93c1-abe97c7032f08ǢcIVA02IGIC91 +0590900102023-03-30T02:43:52.600Z010440852675001220COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001010422005909048&includeAsWebNovelty +es_ESNovedadDVD +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31820070090 +es_ESEste producto contiene poliéster reciclado fabricado a partir de botellas de plástico recicladas. El proceso de producción del poliéster reciclado es de bajo impacto medioambiental ya que gasta menos recursos que otras fibras, genera menos CO2 y evita que las botellas de plástico acaben en vertederos.31845113054 +32406 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png +es_ES&POLYESTER_RECICLADO +es_ES&Polyester reciclado +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201908/21/32406_1_.png020 +es_ES&Polyester reciclado:SUSTAINABILITY_CLOSING_CIRCLE"2021-05-16T22:00Z4065423100870 Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2021-11-30T15:06:55Z +es_ES"TS EPIC AOP SHORT +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0004065423100870$000001513672320048TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401798538153171002056 REEBOKmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201411/17/1249289576_1_.jpg +es_ES Reebok +es_ES&Pantalones y Mallas999.53674013 +es_ES&Pantalones y Mallas 18.000 +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESDDeportes - Contenedor Rebajas PV22997.42771890011 +es_ES@contenedor rebajas deportes pv22N +es_ESRunning997.32324456011 +es_ESRunning +6.000 +es_ESDeportes997.32324246011 +es_ESDeportes +9.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ESDeportes997.42247120011 +es_ESDeportes 16.000 +es_ESLCross - Contenedor SI Exclusivo Online997.38829607011 +es_ES&SI Exclusivo OnlineCDN +es_ESRopa deportiva997.32324452011 +es_ESRopa deportiva +3.000 +es_ESDeportes997.32324246011 +es_ESDeportes +9.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ES Hombre999.17368062013 +es_ES Hombre +1.000 +es_ESRopa training999.52215013 +es_ESRopa training 20.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESFitness997.34622297011 +es_ESFitness +7.000 +es_ESDeportes997.32324246011 +es_ESDeportes +9.000 +es_ES6Cross - Sostenibilidad 2019997.32307653011 +es_ESSostenibilidadCDNN +es_ES Shorts999.14598538013 +es_ES Shorts 11.000 +es_ESRopa deportiva999.12473890013 +es_ESRopa deportiva +1.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESLDeportes - Contenedor 2as rebajas pv22997.43004735011 +es_ES6contenedor 2as rebajas pv22N +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A398154745788091600116392 +es_ESLSANCHEZ FERNANDEZ, FRANCISCO LOS PACOSCARRETERA CADIZ KM.179 "VENTA LOS PACOS",..-29600 MARBELLA - MALAGA (ESPAñA)  +es_ES8432944372677843294437271484329443727218432944372684843294437269184329443727078432944372660843294437349084329443734458432944373438843294437346984329443734768432944373452843294437348384329443741148432944374091843294437410784329443745108432944374503843294437453484329443744978432944374473843294437452784329443744808432944375708843294437569284329443756858432944375678843294437571584329443757228432944375661 +A38630116A38630414A38631246A38631294A38631851 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A386297015800621600130047 +es_ES2ALIMENTARIA SALDUBA, S.L.tCARRETERA ALMONACID,11-50461 ALFAMEN - ZARAGOZA (ESPAñA)  +es_ESPCamisa de niño lino blanco rayas grises +es_ES~Camisa de rayas, cuello mao y manga larga. Material: 100% lino.A386297014444275056 +GOCCO +es_ES +GOCCO5800621600130047 +es_ES2ALIMENTARIA SALDUBA, S.L.tCARRETERA ALMONACID,11-50461 ALFAMEN - ZARAGOZA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeS12CMLCA702WA +es_ESPCamisa de niño lino blanco rayas grises +es_ESPCamisa de niño lino blanco rayas grises +es_ES~Camisa de rayas, cuello mao y manga larga. Material: 100% lino. +calificacion1Acalificacion2Acalificacion3M1calificacion4VVcalificacion5VV004794140908 Años +es_ES8 AñosE +es_ESEspañol190400550907-8 +es_ES7-818171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRINGGocco desp PV21ONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02021-02-26T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02021-09-19T22:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-02-26T23:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Rayas","name":[{"value":"Rayas","locale":"es_ES"}],"external_identifier":"2655617090","description":[{"value":"Rayas","locale":"es_ES"}],"type_lookup":"2504"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas","name":[{"value":"Camisas","locale":"es_ES"}],"external_identifier":"347767090","description":[{"value":"Camisas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Lino","name":[{"value":"Lino","locale":"es_ES"}],"external_identifier":"347685090","description":[{"value":"Lino","locale":"it_IT"},{"value":"Linen","locale":"en_GB"},{"value":"Lino","locale":"es_ES"},{"value":"Lin","locale":"fr_FR"},{"value":"Linho","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001509298880008"2021-02-26T23:00ZDVD(2021-09-19T22:00:01Z"2021-02-26T23:00Z$001082005900699008001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore008H0ea52ee3-b13f-4497-87ff-52f0b701630e DELETE<2023-09-02T17:33:24.868814561Z4dataloader-mongo-kafka-job62023-09-02T17:36:06.002709Z(mixer-gtin-agr-kfreeHe14b0619-dc85-4841-863f-35429628e8d862023-09-02T17:40:42.222850Z,mixer-gtin-calc-pcsflmH1b7c63a4-1d9c-4031-941b-94bd4163d87062023-09-02T17:40:43.222509Z,mixer-gtin-calc-pcsflmH222b1948-2ea7-4471-b46b-ae202fab3f3062023-09-02T22:20:05.378458Z0mixer-product-calc-kfreeH0cd56153-4c5a-45f2-a0ab-f863bc5a70e2<2024-01-19T11:18:08.801174638Z$mixer-xsell-mixtriHd8d38cf2-c84a-4873-9059-ad7529852f7b62024-01-19T11:18:12.443913Z4mixer-packing-units-mixtriHdab35ca9-9e8e-4787-8d9f-6138be4b3d5c62024-01-19T11:18:29.133794Z.mixer-offer-badge-mixbiH183d56b6-434e-41ea-8235-2a17a538895e62024-01-19T11:21:27.709219Z.mixer-offer-badge-mixbiH33e35b9a-a97b-4695-83f2-43bdc40fd03cС8ǢcIVA02IGIC91 +0324400102023-04-24T18:16:12.153Z019740510137001252COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001019725203244054"2021-10-17T22:00Z8435563423706Amarillos +es_ESAmarillosAmarillos +es_ESAmarillosMostaza +es_ESMostaza468072090 +es_ESMostaza600020054 +64614 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/23/___64614O1.png +es_ESCOLOR_MOSTAZA +es_ESColor MostazaMostaza +es_ESMostaza0(2021-10-26T15:39:48Z +es_ES +TURIA +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0008435563423706$000001519880300054TRADICIONAL +es_ESCOLOR_MOSTAZA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/23/___64614O1.png240181439773339942239056JEANSTRACK +es_ESJeansTrack +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ESDeportes997.44463815011 +es_ESDeportes 17.000 +es_ESHCross - Contenedor 2022 Cyber Monday997.44305671011 +es_ESContenedor CMCDN +es_ES Hombre999.17482946013 +es_ES Hombre +1.000 +es_ESRopa999.53891013 +es_ESRopa +2.000 +es_ESMontaña999.53719013 +es_ESMontaña 20.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ESPantalones999.14598534013 +es_ESPantalones +3.000 +es_ESRopa deportiva999.12473890013 +es_ESRopa deportiva +1.000 +es_ES Hombre999.12406165013 +es_ES Hombre +2.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A414372450022802 +es_ESzPantalón de escalada y senderismo de hombre Turia JeansTrack +es_ESEl Turia Eco de Jeanstrack está confeccionado con un tejido elástico de algodón orgánico peinado y Lycra®. El algodón peinado de gran calidad, además de aportar un tacto muy suave, proporciona una mayor resistencia y durabilidad debido a la longitud de sus fibras pero, además, este algodón es orgánico, lo que garantiza que es un producto natural y sostenible. La Lycra®, como fibra elástica, garantiza tanto una gran elasticidad como recuperación de la misma. Al estar dentro de nuestro programa Track Zero, esta prenda no solo es sostenible por su materia prima sino también los procesos aplicando tecnologías como la marcación láser, el ozono o las nano-burbuja. También es importante la huella de carbono del transporte o el embalaje sin plásticos. En este modelo se ha buscado el mayor grado de confort y libertad de movimientos gracias también a su cintura totalmente elástica y al cierre con velcro que evitara cualquier roce y molestia. Con tintura pigmentaria especial y el posterior lavado se consigue un efecto envejecido y desgastado en las costuras que le aportan un look actual y característico igual a cualquier pantalón casual que usas a diario. Bajos ajustables mediante cordón elástico y tanca. Bolsillo tipo relojera para monedas y objetos pequeños. Rodillas reforzadas. Dos bolsillos delanteros y dos bolsillos traseros de tipo jeans. Cintura con con banda elástica de máximo confort. Cierre de la cintura mediante velcro y cremallera. Porta cepillos de escalada para diestros y zurdos. Bordados con el logo y nombre de JeansTrack. El Turia Eco es un pantalón jeans de color pensado para la práctica de escalada y boulder así como para senderismo, trekking, hiking o cualquier otra actividad outdoor pero por su look casual y su comodidad también es un pantalón que puedes usar durante todo el año para viajar o para cualquier otro uso cotidiano como salir a comprar o ir a tomar algo con amigos. El diseño y la fabricación de esta prenda han sido realizados en España (EU) respetando todas las normativas de respeto al medio ambiente y los derechos sociales. Al tratarse de un producto de proximidad, con tu compra, contribuyes al beneficio de tu comunidad.A4143724539942239056JEANSTRACK +es_ESJEANSTRACK15546391600022802 +es_ES,DADAYP,S.L._recargaNFTzCALLE CAMINO FORCALL,S-N-12300 MORELLA - CASTELLON (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize392 +es_ESzPantalón de escalada y senderismo de hombre Turia JeansTrack +es_ESzPantalón de escalada y senderismo de hombre Turia JeansTrack +es_ESEl Turia Eco de Jeanstrack está confeccionado con un tejido elástico de algodón orgánico peinado y Lycra®. El algodón peinado de gran calidad, además de aportar un tacto muy suave, proporciona una mayor resistencia y durabilidad debido a la longitud de sus fibras pero, además, este algodón es orgánico, lo que garantiza que es un producto natural y sostenible. La Lycra®, como fibra elástica, garantiza tanto una gran elasticidad como recuperación de la misma. Al estar dentro de nuestro programa Track Zero, esta prenda no solo es sostenible por su materia prima sino también los procesos aplicando tecnologías como la marcación láser, el ozono o las nano-burbuja. También es importante la huella de carbono del transporte o el embalaje sin plásticos. En este modelo se ha buscado el mayor grado de confort y libertad de movimientos gracias también a su cintura totalmente elástica y al cierre con velcro que evitara cualquier roce y molestia. Con tintura pigmentaria especial y el posterior lavado se consigue un efecto envejecido y desgastado en las costuras que le aportan un look actual y característico igual a cualquier pantalón casual que usas a diario. Bajos ajustables mediante cordón elástico y tanca. Bolsillo tipo relojera para monedas y objetos pequeños. Rodillas reforzadas. Dos bolsillos delanteros y dos bolsillos traseros de tipo jeans. Cintura con con banda elástica de máximo confort. Cierre de la cintura mediante velcro y cremallera. Porta cepillos de escalada para diestros y zurdos. Bordados con el logo y nombre de JeansTrack. El Turia Eco es un pantalón jeans de color pensado para la práctica de escalada y boulder así como para senderismo, trekking, hiking o cualquier otra actividad outdoor pero por su look casual y su comodidad también es un pantalón que puedes usar durante todo el año para viajar o para cualquier otro uso cotidiano como salir a comprar o ir a tomar algo con amigos. El diseño y la fabricación de esta prenda han sido realizados en España (EU) respetando todas las normativas de respeto al medio ambiente y los derechos sociales. Al tratarse de un producto de proximidad, con tu compra, contribuyes al beneficio de tu comunidad. calificacion1Acalificacion2Acalificacion3RTcalificacion4VVcalificacion5EPcalificacion6MO00N479445090XL +es_ESXLE +es_ESEspañol479445090XL +es_ESXL477062090Español +Tallapler4twpwa2rdqpz3c2qg46aax5qpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-28T15:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-11-30T05:25:30.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-10-26T15:48:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}MANYag3zdkhi7a32y6 ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347622090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1617"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347691090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón orgánico","name":[{"value":"Algodón orgánico","locale":"es_ES"}],"external_identifier":"477823090","description":[{"value":"Algodón orgánico","locale":"es_ES"},{"value":"Algodão orgânico","locale":"pt_PT"},{"value":"Coton biologique","locale":"fr_FR"},{"value":"Organic cotton","locale":"en_GB"},{"value":"Cotone organico","locale":"it_IT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":97},{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Lycra","name":[{"value":"Lycra","locale":"es_ES"}],"external_identifier":"359253090","description":[{"value":"Lycra","locale":"es_ES"},{"value":"Lycra","locale":"pt_PT"},{"value":"Lycra","locale":"fr_FR"},{"value":"Lycra","locale":"en_GB"},{"value":"Lycra","locale":"it_IT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":3}]}]}MANYatc4u6vijhkdp6 NUMBER2021Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001519880300054(2021-10-26T15:48:01ZDVD(2022-11-30T05:25:30Z"2022-08-28T15:00Z$001019725203244054001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore054Hf910c4f1-466c-4851-a76a-d34e7aefe460 DELETE<2023-09-02T17:37:14.087089046Z4dataloader-mongo-kafka-job62023-09-02T17:46:03.264867Z(mixer-gtin-agr-kfreeHf3c56faa-121c-4761-ad3f-f02ffb6ab29062023-09-02T17:47:50.250291Z,mixer-gtin-calc-pcsflmHa8998303-ff5b-4d60-bcb2-b58ff36fae1c62023-09-02T17:47:50.822535Z,mixer-gtin-calc-pcsflmH8c9d6011-afb1-43ee-bcec-08090d536df662023-09-03T03:04:00.637153Z0mixer-product-calc-kfreeH99b6aead-e90b-46cb-8850-6d838e419dbd<2024-01-19T11:18:28.068233429Z$mixer-xsell-mixtriHea390841-225f-49d2-b316-60fb8e54180f62024-01-19T11:18:28.476131Z4mixer-packing-units-mixtriHca641d8c-f564-456b-b1d8-defd26d24f1562024-01-19T11:18:29.134527Z.mixer-offer-badge-mixbiH89c3a6db-5f3e-49fa-95ba-a266be08358b62024-01-19T11:21:27.710190Z.mixer-offer-badge-mixbiH7606a256-f90d-453f-8419-b659b9347d92ҡ8ǢcLoffer(A42843349).publish_ends_extendedIVA02IGIC91 +10898001015341610889001014COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001015301410898004"2022-02-14T23:00Z0723088562528 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2022-02-15T15:06:17Z +es_ES(DEBOSSED LONG ANORAK158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000723088562528$000001525944420004TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401828919839896169056(MICHAEL MICHAEL KORS +es_ES(Michael Michael Kors +es_ES Parkas999.39089874013 +es_ES Parkas +4.000 +es_ESAbrigos999.39072580013 +es_ESAbrigos 13.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN +es_ESRopa997.41964062011 +es_ESRopa +5.000 +es_ESModa Mujer997.41875780011 +es_ESModa Mujer 32.000 +es_ES6Cross - Contenedor 8DO pv22997.41837795011 +es_ES&Contenedor 8DO pv22CDNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42843349 +es_ES Parkas999.39089874013 +es_ES Parkas +4.000 +es_ESAbrigos999.39072580013 +es_ESAbrigos 13.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNNN5949451600974303 +es_ES&ARENAS ESTEVE, JOSE|CALLE CREVILLENTE,25-6,..-46022 VALENCIA - VALENCIA (ESPAñA)  +es_ESJParka de mujer cerrada con cremallera +es_ESGabardina cerrada con botones y ajustada con cinturón en cintura y solapa trasera sellado con el logo de la firma.A42843349896169056MICHAEL KORS +es_ESMICHAEL KORS5949451600974303 +es_ES&ARENAS ESTEVE, JOSE|CALLE CREVILLENTE,25-6,..-46022 VALENCIA - VALENCIA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeHA321879 +es_ESJParka de mujer cerrada con cremallera +es_ESJParka de mujer cerrada con cremallera +es_ESGabardina cerrada con botones y ajustada con cinturón en cintura y solapa trasera sellado con el logo de la firma. +calificacion1Acalificacion2Acalificacion3DRcalificacion4VVcalificacion5BPDN479317090 +42-44 +es_ES +42-44E +es_ESEspañol479437090L +es_ESL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa2ynyjkfoo2woqTIMESTAMP02098-12-31T23:00:01.000ZONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-11T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-06T22:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-10T03:59:24.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavado en seco","name":[{"value":"Lavado en seco","locale":"es_ES"}],"external_identifier":"484879090","description":[{"value":"Lavado en seco","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}}{"identifier":"No necesita planchado","name":[{"value":"No necesita planchado","locale":"es_ES"}],"external_identifier":"392861090","description":[{"value":"No necesita planchado","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Limpieza en seco con precaución","name":[{"value":"Limpieza en seco con precaución","locale":"es_ES"}],"external_identifier":"484890090","description":[{"value":"Limpieza en seco con precaución","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Microestampado","name":[{"value":"Microestampado","locale":"es_ES"}],"external_identifier":"25521451090","description":[{"value":"Microestampado","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Alto","name":[{"value":"Alto","locale":"es_ES"}],"external_identifier":"485139090","description":[{"value":"Alto","locale":"es_ES"}],"type_lookup":"1595"}ONEabf2vvifj26pzi ENTITY{"identifier":"Corto","name":[{"value":"Corto","locale":"es_ES"}],"external_identifier":"2655626090","description":[{"value":"Corto","locale":"es_ES"}],"type_lookup":"2507"}ONEac5swxsdtmjapu ENTITY{"identifier":"Parkas","name":[{"value":"Parkas","locale":"es_ES"}],"external_identifier":"2680994090","description":[{"value":"Parkas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Larga","name":[{"value":"Larga","locale":"es_ES"}],"external_identifier":"347643090","description":[{"value":"Larga","locale":"es_ES"}],"type_lookup":"1597"}MANYagio3trrjaqhgg ENTITY{"identifier":"Sintético","name":[{"value":"Sintético","locale":"es_ES"}],"external_identifier":"477968090","description":[{"value":"Sintético","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Abrigos","name":[{"value":"Abrigos","locale":"es_ES"}],"external_identifier":"2700610090","description":[{"value":"Abrigos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001525944420004(2022-03-10T03:59:24Z(2022-10-06T22:00:01Z"2022-09-11T22:00Z$001015301410898004001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore004H9e991c0d-2124-486d-839e-b1e3d1f0075d DELETE<2023-09-02T17:31:16.906482966Z4dataloader-mongo-kafka-job62023-09-02T17:31:48.986971Z(mixer-gtin-agr-kfreeHd0c589e6-eac6-441c-b6d2-cb1f01fc7aee62023-09-02T17:38:52.015233Z,mixer-gtin-calc-pcsflmH1c072fe3-5ef0-4e86-a9c2-652b1f8c1e8262023-09-02T17:38:58.114503Z,mixer-gtin-calc-pcsflmHf7ffe05d-2b30-4719-8714-858010eba14b62023-09-03T03:00:50.087733Z0mixer-product-calc-kfreeH005b85c3-32f5-4cdc-ba1d-8bb4bb0d7d2a<2024-01-19T11:18:28.261763656Z$mixer-xsell-mixtriH2f0d5d15-7c75-4425-8170-1f68c3ac318f62024-01-19T11:18:28.635095Z4mixer-packing-units-mixtriH549ce6fa-c698-4c54-bacd-20359c3251b062024-01-19T11:18:29.142484Z.mixer-offer-badge-mixbiH8f0b8cca-21c3-4db0-b6b6-b8a0d66240b662024-01-19T11:21:27.712265Z.mixer-offer-badge-mixbiHe79e892c-71d1-43f3-b880-ad10c25551ddԡ8ǢcLoffer(A40613241).publish_ends_extendedIVA02IGIC91 +05261001003040827223001715COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001003071505261037&includeAsWebNovelty +es_ESNovedadDVD Negros +es_ES Negros Negros +es_ES Negros +Negro +es_ES +Negro347149090 +es_ES +Negro599042054 +25525 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png +es_ESCOLOR_NEGRO +es_ESColor Negro +Negro +es_ES +Negro0(2021-11-26T16:09:58Z +es_ES*BOTIN TACON CADENA CO158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401806814194$000001516597450037TRADICIONAL +es_ESCOLOR_NEGRO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/28/___25525O3.png2401806814194161993056 +DANSI +es_ES +Dansi +es_ESBotines999.39073041013 +es_ESBotines +3.000 +es_ESZapatos999.39072676013 +es_ESZapatos +2.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40613241 +es_ESBotines999.39073041013 +es_ESBotines +3.000 +es_ESZapatos999.39072676013 +es_ESZapatos +2.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0006770 +es_ES.DYCSAMON CALZADOS, S.L. +es_ESNBotines de mujer en piel de color negro +es_ESBotines de piel napa en color negro con tacón encastrado y piso con cerco. Destaca sobremanera el precioso adorno de cadena en la parte delantera del botín y pasamanería de piel entrelazada al tono del corte. Tacón tipo bloque de 6 cm de altura. Cierre de cremallera.A40613241161993056 +DANSI +es_ES +DANSI8906111600006770 +es_ES.DYCSAMON CALZADOS, S.L.nCALLE VITORIA KENT,47-03206 ELCHE - ALICANTE (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSize4084 +es_ESNBotines de mujer en piel de color negro4084 +es_ESNBotines de mujer en piel de color negro +es_ESBotines de piel napa en color negro con tacón encastrado y piso con cerco. Destaca sobremanera el precioso adorno de cadena en la parte delantera del botín y pasamanería de piel entrelazada al tono del corte. Tacón tipo bloque de 6 cm de altura. Cierre de cremallera. calificacion1A7calificacion2Acalificacion3ROcalificacion4VVcalificacion5NScalificacion6CA00N47926409037 +es_ES37E +es_ESEspañol47926409037 +es_ES37477062090Español +Tallapler4twpwa2rdqpwe2kceprh5w3aphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRING.Publicar calif agotadorONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-08-04T00:35:28.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-05T00:35:28.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02021-11-27T07:32:01.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE4MANYa3mfirlezq5meo NUMBER +100.0ONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa6t5qpj7cwnmaw NUMBER +100.0MANYa7jpc7s7go77wi ENTITY{"identifier":"Mezcla de fibras","name":[{"value":"Mezcla de fibras","locale":"es_ES"}],"external_identifier":"477893090","description":[{"value":"Mezcla de fibras","locale":"es_ES"}],"type_lookup":"1633"} @NULL@{"identifier":"Piel Caprina","name":[{"value":"Piel Caprina","locale":"es_ES"}],"external_identifier":"477918090","description":[{"value":"Piel Caprina","locale":"es_ES"}],"type_lookup":"1633"}ONEa7xqyqnqtfqof6 ENTITY{"identifier":"Botines","name":[{"value":"Botines","locale":"es_ES"}],"external_identifier":"492701090","description":[{"value":"Botines","locale":"es_ES"}],"type_lookup":"1620"}MANYaao3an6xqyn27u ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}MANYaf2vrsw47f76eg ENTITY{"identifier":"Bloque","name":[{"value":"Bloque","locale":"es_ES"}],"external_identifier":"3020291090","description":[{"value":"Bloque","locale":"es_ES"}],"type_lookup":"1614"}ONEaffhfwfkp27d3k ENTITY{"identifier":"cm","name":[{"value":"cm","locale":"es_ES"}],"external_identifier":"347186090","description":[{"value":"cm","locale":"es_ES"}],"type_lookup":"204"}MANYafrdyt4ml6523m ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Caucho vulcanizado","name":[{"value":"Caucho vulcanizado","locale":"es_ES"}],"external_identifier":"477838090","description":[{"value":"Caucho vulcanizado","locale":"es_ES"}],"type_lookup":"1633"}ONEalnwwhqri3drmq ENTITY{"identifier":"Cremallera","name":[{"value":"Cremallera","locale":"es_ES"}],"external_identifier":"348040090","description":[{"value":"Cremallera","locale":"es_ES"}],"type_lookup":"1574"}MANYamf7ns2ejiozuc NUMBER +100.0 @NULL@ +100.0MANYamzex7cmn57eei ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Piel napa","name":[{"value":"Piel napa","locale":"es_ES"}],"external_identifier":"477925090","description":[{"value":"Piel napa","locale":"es_ES"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Otoño-Invierno","name":[{"value":"Otoño-Invierno","locale":"es_ES"}],"external_identifier":"479797090","description":[{"value":"Otoño-Invierno","locale":"es_ES"}],"type_lookup":"1577"}ONEaug6jmbvxng2pi ENTITY{"identifier":"Baja","name":[{"value":"Baja","locale":"es_ES"}],"external_identifier":"467441090","description":[{"value":"Baja","locale":"es_ES"}],"type_lookup":"1608"}ONEauik4rxccjjcze ENTITY{"identifier":"Redonda","name":[{"value":"Redonda","locale":"es_ES"}],"external_identifier":"3020307090","description":[{"value":"Redonda","locale":"es_ES"}],"type_lookup":"1612"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Botines","name":[{"value":"Botines","locale":"es_ES"}],"external_identifier":"492701090","description":[{"value":"Botines","locale":"es_ES"}],"type_lookup":"1620"}MANYauqqk66n7fk6uu ENTITY{"identifier":"Piel","name":[{"value":"Piel","locale":"es_ES"}],"external_identifier":"347595090","description":[{"value":"Piel","locale":"es_ES"}],"type_lookup":"1633"}ONEauur46vhpycka4 ENTITY{"identifier":"Zapatos mujer","name":[{"value":"Zapatos mujer","locale":"es_ES"}],"external_identifier":"357142090","description":[{"value":"Zapatos mujer","locale":"es_ES"}],"type_lookup":"1611"}ONEaw6vkfjbbbqd24 NUMBER6MANYaxhbfopxaa6ppy ENTITY{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"} @NULL@{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"es_ES"}],"type_lookup":"214"}MANYaxr5m2ljibnmui NUMBER2021MANYaysizsllntmwzgCOMPLEX{"ahx7en5mskblj4":{"identifier":"Forro","name":[{"value":"Forro","locale":"es_ES"}],"external_identifier":"477728090","description":[{"value":"Lining","locale":"en_GB"},{"value":"Forro","locale":"es_ES"},{"value":"Doublure","locale":"fr_FR"},{"value":"Forro","locale":"pt_PT"}],"type_lookup":"1576"},"abjlulhwauqmm2":[{"abywf4lkkpef2w":100.0,"a22ina6zdhutbm":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"aed5i4gt3gvp5u":{"identifier":"Mezcla de fibras","name":[{"value":"Mezcla de fibras","locale":"es_ES"}],"external_identifier":"477893090","description":[{"value":"Fibre miste","locale":"it_IT"},{"value":"Mixed fibres","locale":"en_GB"},{"value":"Mezcla de fibras","locale":"es_ES"},{"value":"Mélange de fibres","locale":"fr_FR"},{"value":"Mistura de fibras","locale":"pt_PT"}],"type_lookup":"1633"}}]}{"ahx7en5mskblj4":{"identifier":"Plantilla","name":[{"value":"Plantilla","locale":"es_ES"}],"external_identifier":"10765251090","description":[{"value":"Insole","locale":"en_GB"},{"value":"Plantilla","locale":"es_ES"},{"value":"Semelle intérieure","locale":"fr_FR"},{"value":"Palmilha","locale":"pt_PT"}],"type_lookup":"1576"},"abjlulhwauqmm2":[{"abywf4lkkpef2w":100.0,"a22ina6zdhutbm":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"aed5i4gt3gvp5u":{"identifier":"Piel Caprina","name":[{"value":"Piel Caprina","locale":"es_ES"}],"external_identifier":"477918090","description":[{"value":"Pelle di Capra","locale":"it_IT"},{"value":"Goatskin","locale":"en_GB"},{"value":"Piel Caprina","locale":"es_ES"},{"value":"Cuir caprin","locale":"fr_FR"},{"value":"Pele de caprino","locale":"pt_PT"}],"type_lookup":"1633"}}]}Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001516597450037(2021-11-27T07:32:01Z(2022-08-05T00:35:28Z(2022-08-04T00:35:28Z$001003071505261037001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore037H2831749d-5fd3-4328-ba36-a6fc41260ed5 DELETE<2023-09-02T17:09:18.496878853Z4dataloader-mongo-kafka-job62023-09-02T17:09:28.096612Z(mixer-gtin-agr-kfreeHaf133f4f-9e58-487d-a284-ef52b8f1305662023-09-02T17:09:34.299178Z,mixer-gtin-calc-pcsflmH741781d9-fdd8-401f-8953-0ec165d5306962023-09-02T17:09:34.326240Z,mixer-gtin-calc-pcsflmH1d2f07a6-a6ad-433f-882f-53b8e7bede5b62023-09-02T22:26:03.793515Z0mixer-product-calc-kfreeHf33b05c3-e405-4d32-9a07-07fc8d0b08e6<2024-01-19T11:18:12.541406458Z$mixer-xsell-mixtriH2b602070-aab8-4ea0-8e6b-4cf6db51643962024-01-19T11:18:12.677782Z4mixer-packing-units-mixtriHf02db9fd-e032-40d0-97d2-e3203b98329362024-01-19T11:18:29.427730Z.mixer-offer-badge-mixbiH20a6120f-c79f-4f0c-9a6d-320c5584313462024-01-19T11:21:27.787465Z.mixer-offer-badge-mixbiHe6d56fe1-64cd-4472-9d25-7ec269cb6c51֡8ǢcLoffer(A43120244).publish_ends_extendedIVA02IGIC91 +01790001A085542224240001400COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001085540001790004&includeAsWebNovelty +es_ESNovedadDVD"2022-03-06T23:00Z0500086276691 Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2022-04-22T10:59:31Z +es_ESTCAMP GRAPHIC T155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000500086276691$000001527347560004TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401831673063894121056GAP +es_ESGap +es_ESCamisetas999.39072569013 +es_ESCamisetas 10.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN155 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A43120244 +es_ESCamisetas999.39072569013 +es_ESCamisetas 10.000 +es_ESRopa999.39072550013 +es_ESRopa +1.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN0907458 +es_ESGAP EUROPE LTD +es_ESRCamiseta de hombre básica dibujo frontal +es_ESCamiseta básica dibujo frontal con manga corta y cuello redondo.A43120244894121056GAP +es_ESGAP16086051600907458 +es_ESGAP EUROPE LTD|CALLE 6ST ANDREW STREET 5TH FLOOR,.- LONDON - (PAISES BAJOS) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize 867857 +es_ESRCamiseta de hombre básica dibujo frontal +es_ESRCamiseta de hombre básica dibujo frontal +es_ESCamiseta básica dibujo frontal con manga corta y cuello redondo. calificacion1Acalificacion2Acalificacion3RVcalificacion4VVcalificacion5AAcalificacion62100N479437090L +es_ESLE +es_ESEspañol479437090L +es_ESL477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-29T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-01T03:09:37.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-06-03T06:35:43.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Dibujo frontal","name":[{"value":"Dibujo frontal","locale":"es_ES"}],"external_identifier":"25550603090","description":[{"value":"Dibujo frontal","locale":"es_ES"}],"type_lookup":"2504"}MANYaa32kr4uvwxd4q ENTITY{"identifier":"Redondo","name":[{"value":"Redondo","locale":"es_ES"}],"external_identifier":"485162090","description":[{"value":"Redondo","locale":"es_ES"}],"type_lookup":"1595"}MANYadla3f5bsg737w ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Otras fibras","name":[{"value":"Otras fibras","locale":"es_ES"}],"external_identifier":"31814873090","description":[{"value":"Other fibres","locale":"en_GB"},{"value":"Otras fibras","locale":"es_ES"},{"value":"Autres fibres","locale":"fr_FR"},{"value":"Outras fibras","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001527347560004(2022-06-03T06:35:43Z(2022-10-01T03:09:37Z"2022-09-29T22:00Z$001085540001790004001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore004He1f355ad-5c00-4a06-9837-51b451b0ad78 DELETE<2023-09-02T17:29:09.533179858Z4dataloader-mongo-kafka-job62023-09-02T17:29:38.650335Z(mixer-gtin-agr-kfreeHd8992814-55ce-46bb-ab66-6b9dc427b55662023-09-02T17:34:09.622156Z,mixer-gtin-calc-pcsflmHb97a8a51-cf68-4a81-aa63-ca8c7bbf1b9b62023-09-02T17:34:14.521450Z,mixer-gtin-calc-pcsflmH74389afa-a25b-4dd8-8b16-96966d5f6fec62023-09-02T22:26:16.618208Z0mixer-product-calc-kfreeH68e835bc-5745-41d1-b70f-36b1d338bcea<2024-01-19T11:18:12.607975563Z$mixer-xsell-mixtriH105b4ac2-546f-4adc-a17a-5cb9f74a2a8562024-01-19T11:18:12.681085Z4mixer-packing-units-mixtriH3be74d13-689b-49df-8a02-2074dbd769b162024-01-19T11:18:29.428131Z.mixer-offer-badge-mixbiHb5849fce-5c5c-48c4-99df-249cb7ff77cd62024-01-19T11:21:27.788223Z.mixer-offer-badge-mixbiHa68120a6-cbc6-4eef-b1af-cfd161bfc9eaء8ǢcLoffer(A40543142).publish_ends_extendedIVA02IGIC91 +01289001052041347315001411COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001052041101289010 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31820033090 +es_ESAl comprar este producto estás apoyando la producción responsable de algodón a través del programa Better Cotton Initiative. El objetivo de esta asociación sin ánimo de lucro es potenciar el desarrollo económico de las zonas productoras de algodón y mejorar las condiciones de sus trabajadores. Esta asociación también asegura la reducción del impacto medioambiental del algodón mediante un uso más eficiente del agua y el cuidado responsable de la tierra conservando su biodiversidad.31845058054 +12044 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png +es_ES0INICIATIVA_BETTER_COTTON +es_ES0Iniciativa Better Cotton +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201906/26/12044_2_.png022 +es_ES0Iniciativa Better Cotton*SUSTAINABILITY_ORIGIN Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2022-01-17T17:09:07Z +es_ES*PANT C OXFORD VELEROS156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401806018899$000001516303760010TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401806018899151975056COTTON JUICE +es_ESCotton Juice +es_ESPantalones999.39089929013 +es_ESPantalones +4.000 +es_ESPijamas999.39089920013 +es_ESPijamas +5.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A40543142 +es_ESPantalones999.39089929013 +es_ESPantalones +4.000 +es_ESPijamas999.39089920013 +es_ESPijamas +5.000 +es_ES +Niño999.39073118013 +es_ES +Niño +2.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN5925041600923805 +es_ES(CANNON HYGIENE, S.A.CALLE MAR MEDITERRANEO,1-28830 SAN FERNANDO DE HENARES - MADRID (ESPAñA)  +es_ES4Pantalón de niño veleros +es_ESPantalón corto en color azul con estampado de veleros all over.A40543142151975056COTTON JUICE +es_ESCOTTON JUICE5925041600923805 +es_ES(CANNON HYGIENE, S.A.CALLE MAR MEDITERRANEO,1-28830 SAN FERNANDO DE HENARES - MADRID (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeC22N7804 +es_ES4Pantalón de niño veleros +es_ES4Pantalón de niño veleros +es_ESPantalón corto en color azul con estampado de veleros all over. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5VV00N47909609010 Años +es_ES10 AñosE +es_ESEspañol190400560909-10 +es_ES9-1018171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4brnkellmqilc STRING(Fuerzo Rebajas 80822ONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-16T03:07:07.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-17T03:07:07.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-05-02T22:00:01.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Microestampado","name":[{"value":"Microestampado","locale":"es_ES"}],"external_identifier":"25521451090","description":[{"value":"Microestampado","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Pantalones","name":[{"value":"Pantalones","locale":"es_ES"}],"external_identifier":"347622090","description":[{"value":"Pantalones","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niño","name":[{"value":"Niño","locale":"es_ES"}],"external_identifier":"347765090","description":[{"value":"Niño","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Pijamas","name":[{"value":"Pijamas","locale":"es_ES"}],"external_identifier":"8610839090","description":[{"value":"Pijamas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001516303760010(2022-05-02T22:00:01Z(2022-09-17T03:07:07Z(2022-09-16T03:07:07Z$001052041101289010001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore010Ha0c3ed39-2389-4d03-93ef-430e05ee6d30 DELETE<2023-09-02T17:22:44.437901747Z4dataloader-mongo-kafka-job62023-09-02T17:22:49.457189Z(mixer-gtin-agr-kfreeH455c3fa3-6b58-49e0-8607-d4dafc727e1562023-09-02T17:23:54.413495Z,mixer-gtin-calc-pcsflmH72e2b7b6-480b-41a3-aea7-43a9df31a5e062023-09-02T17:23:55.210599Z,mixer-gtin-calc-pcsflmH2ba7750b-9b53-4f98-be53-2cf73e136c1062023-09-02T22:08:57.053921Z0mixer-product-calc-kfreeHc4e8af1d-e220-4b8a-ab44-26b275460386<2024-01-19T11:18:28.744606276Z$mixer-xsell-mixtriH2a459c4c-6f4b-4afc-b66a-fa88eb9e915362024-01-19T11:18:29.233758Z4mixer-packing-units-mixtriH4dcb75d1-a3d8-4089-a17f-2b5aa6ba1f5362024-01-19T11:18:29.660080Z.mixer-offer-badge-mixbiH7595a8f4-30f6-4320-af97-12822c0b064162024-01-19T11:21:27.790996Z.mixer-offer-badge-mixbiHa4f2b13b-6740-4f8a-9941-fbd5f94ad87cܡ8Ϣcn +$+ +}&Loffer(A19695555).publish_ends_extendedIVA02IGIC92 +10269001005113072919001134COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001005113410269 &includeAsWebNovelty +es_ESNovedadDVD"2016-07-13T22:00Z2051134102694"2016-07-13T22:00Z00936249182260(2016-08-08T13:54:08Z +es_ESANGELUS7 +es_ES Discos274975090 Discos395ML +es_ESml +1.0000093624918226$0000000001434039852401612106032140698056 WARNER +es_ES Warner +es_ES,Brasil - Bossa - Samba999.5224831013 +es_ES,Brasil - Bossa - Samba +3.000 +es_ES8Músicas del Mundo y New Age999.54190013 +es_ES8Músicas del Mundo y New Age 10.000 +es_ESMúsica999.54175013 +es_ESMúsicaNNN7 +es_ES Discos274975090 Discos395A19695555 +es_ES,Brasil - Bossa - Samba999.5224831013 +es_ES,Brasil - Bossa - Samba +3.000 +es_ES8Músicas del Mundo y New Age999.54190013 +es_ES8Músicas del Mundo y New Age 10.000 +es_ESMúsica999.54175013 +es_ESMúsicaNNN5220341600458315 +es_ES0WARNER MUSIC SPAIN, S.L.CALLE JUAN HURTADO DE MENDOZA,3-28036 MADRID - MADRID (ESPAñA)  +es_ESAngelus (CD)A196955551406980563X15 +es_ES3X155220341600458315 +es_ES0WARNER MUSIC SPAIN, S.L.CALLE JUAN HURTADO DE MENDOZA,3-28036 MADRID - MADRID (ESPAñA) 998.00078 +es_ESMúsica998.00077 +es_ESMúsica998 +es_ES@Jerarquía de Ficha de Productos0093624918226 +es_ESAngelus (CD) +es_ESAngelus (CD) +calificacion1Acalificacion2Ecalificacion3M5calificacion4VVcalificacion5AC06pler4twpwa2rdqpotazgohmkmafk MANYa5hilbj32lamhqCOMPLEX{"apj2uzph6fmmkk":1,"avgcdiqt7a2aza":{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"346108090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"727"},"acmt6g7r6qhx2u":[{"au7f4xdiq7un2c":"Seis Horas Da Tarde","a4ry3szh3gtire":1},{"au7f4xdiq7un2c":"Estrelada","a4ry3szh3gtire":2},{"au7f4xdiq7un2c":"De Um Modo Geral...","a4ry3szh3gtire":3},{"a4ry3szh3gtire":4,"au7f4xdiq7un2c":"Angelus"},{"au7f4xdiq7un2c":"Coisas De Minas","a4ry3szh3gtire":5},{"au7f4xdiq7un2c":"Hello Goodbye","a4ry3szh3gtire":6},{"au7f4xdiq7un2c":"Sofro Calado","a4ry3szh3gtire":7},{"au7f4xdiq7un2c":"Clube Da Esquina No 2","a4ry3szh3gtire":8},{"au7f4xdiq7un2c":"Meu Veneno","a4ry3szh3gtire":9},{"au7f4xdiq7un2c":"Only A Dream In Rio","a4ry3szh3gtire":10},{"au7f4xdiq7un2c":"Qualquer Coisa A Haver Com O Paraiso","a4ry3szh3gtire":11},{"au7f4xdiq7un2c":"Vera Cruz","a4ry3szh3gtire":12},{"au7f4xdiq7un2c":"Novena","a4ry3szh3gtire":13},{"au7f4xdiq7un2c":"Amor Amigo","a4ry3szh3gtire":14},{"au7f4xdiq7un2c":"Sofro Caldo","a4ry3szh3gtire":15}]}ONEafo2anbgjhsm24 STRING`[{"locale":"es_ES","value":"MUSICAS DEL MUNDO"}]ONEagicfmz77ja53a STRINGL[{"locale":"es_ES","value":"AMERICA"}]ONEahfff3nxlhwulu STRINGCBONEajpdzknt6uts6y ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"347028090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"755"}MANYal3xisuwvftmyk ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"10121506090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"910"}ONEaoebsmn4ezopnm STRING001ONEap2hatgiudxb3e STRINGANGELUSONEap7y5h3tps6gkg STRING005MANYaqrilmr6vaykxs NUMBER1ONEara2vukzeq2ngmTIMESTAMP02016-07-28T22:00:00.000ZONEarnjhlabcabx7u STRING001MANYav6kjmaio2grso ENTITY{"identifier":"CD","name":[{"value":"CD","locale":"es_ES"}],"external_identifier":"347028090","description":[{"value":"CD","locale":"es_ES"}],"type_lookup":"755"}ONEav7wm2uhmbgqwk STRING$NASCIMENTO, MILTONMANYavajjx54jfzn6kCOMPLEX{"agpvq6oxw255wq":[{"ao2qh3g5n6csh4":{"identifier":"001171","name":[{"value":"Nascimento, Milton","locale":"es_ES"}],"external_identifier":"600998055","given_name":"Nascimento, Milton"}}],"aelpy27erl64ea":{"identifier":"Artista","name":[{"value":"Artista","locale":"es_ES"}],"external_identifier":"42203958090","description":[{"value":"Artista","locale":"es_ES"}],"type_lookup":"732"}}MANY*musica_iss_calculatedCOMPLEX{"name":"Nascimento, Milton","rol":"Artista","grouper":"musicCast","normalize_name_grouper":"musicCast|nascimento,-milton"}Musica_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEANtrueONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-01-19T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-10T03:21:27.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02016-08-08T13:57:24.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000143403985(2016-08-08T13:57:24Z(2022-08-10T03:21:27Z"2022-01-19T23:00Z$001005113410269 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H1fd0d9f9-1536-479b-96d7-5daf6321f4e8 DELETE<2023-09-02T17:11:24.459854211Z4dataloader-mongo-kafka-job62023-09-02T17:11:40.381590Z(mixer-gtin-agr-kfreeHd2ab1496-d549-4175-a6f7-4b2c5f66360362023-09-02T17:11:44.921400Z,mixer-gtin-calc-pcsflmH416b8a71-217c-42e6-9b17-1bc10ba72a5262023-09-02T17:11:54.104907Z,mixer-gtin-calc-pcsflmH0e2bfed0-5706-4bdb-945a-ad642c13c73862023-09-03T02:39:51.775270Z0mixer-product-calc-kfreeH4e6b1983-b377-4707-b603-e7c7cc016bb1<2024-01-19T11:18:12.865337004Z$mixer-xsell-mixtriHa1a026a1-a290-4b3e-ade0-71a641a638c662024-01-19T11:18:13.008680Z4mixer-packing-units-mixtriHa28784d2-600f-48ce-b691-64cf6d831c9462024-01-19T11:18:29.670626Z.mixer-offer-badge-mixbiH52374a48-3029-48ec-a101-d2442179778562024-01-19T11:21:27.792174Z.mixer-offer-badge-mixbiH11b8e66e-1865-4801-bc00-cf99253d0d53ޡ8ϢcLoffer(A42796168).publish_ends_extendedIVA02IGIC91 +00874001069541643488001011(EXPLOTACIÓN DIRECTA +es_ES(EXPLOTACIÓN DIRECTASTERLING +es_ESSTERLING$001069501100874112&includeAsWebNovelty +es_ESNovedadDVD"2022-02-10T23:00Z3666072281647 Verdes +es_ES Verdes Verdes +es_ES Verdes +Verde +es_ES +Verde347197090 +es_ES +Verde597003054 +11929 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___11929O2.png +es_ESCOLOR_VERDE +es_ESColor Verde +Verde +es_ES +Verde0(2022-02-18T09:09:17Z +es_ES JERSEY156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0003666072281647$000001525786180112TRADICIONAL +es_ESCOLOR_VERDE +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___11929O2.png2401828456570130409056PETIT BATEAUmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/91/88/8/00001291888/00001291888326mM1011.jpg +es_ESPetit Bateau +es_ESJerseis999.39089847013 +es_ESJerseis +1.000 +es_ES(Jerséis y Chaquetas999.39089844013 +es_ES(Jerséis y Chaquetas 12.000 +es_ESBebé Niño999.39073122013 +es_ESBebé Niño +4.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN156 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A42796168 +es_ESJerseis999.39089847013 +es_ESJerseis +1.000 +es_ES(Jerséis y Chaquetas999.39089844013 +es_ES(Jerséis y Chaquetas 12.000 +es_ESBebé Niño999.39073122013 +es_ESBebé Niño +4.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN4982651600157586 +es_ES2PETIT BATEAU IBERICA S.L.CALLE RAMBLA CATALUÑA,62.5-08006 BARCELONA - BARCELONA (ESPAñA)  +es_ESTJersey marino con motivo de ancla de bebé +es_ESvTapeta de botones en el hombro para una fácil colocación.Un jersey con un «look» marino e intemporal, indispensable en el armario del bebé.A42796168130409056PETIT BATEAU +es_ESPETIT BATEAU4982651600157586 +es_ES2PETIT BATEAU IBERICA S.L.CALLE RAMBLA CATALUÑA,62.5-08006 BARCELONA - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize +A03IN +es_ESTJersey marino con motivo de ancla de bebé +es_ESTJersey marino con motivo de ancla de bebé +es_ESvTapeta de botones en el hombro para una fácil colocación.Un jersey con un «look» marino e intemporal, indispensable en el armario del bebé. +calificacion1Acalificacion2Acalificacion3M1calificacion4VVcalificacion5VV00N479092090 1 Año +es_ES 1 AñoE +es_ESEspañol479092090 1 Año +es_ES 1 Año477062090Español +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4brnkellmqilc STRINGONEa2x4yaxk3sajg2 STRINGANDRE DE TOTHONEa3qki7zb6ptf5m STRING|[{"locale":"es_ES","value":"Dark waters / Monkey on my back"}]ONEa4vh5lymazgkpc STRINGL[{"locale":"es_ES","value":"INTRIGA"}]ONEa7efot6m2c2lag STRINGDSONEaagfg5vkt4qsn4 ENTITY{"identifier":"Sonora","name":[{"value":"Sonora","locale":"es_ES"}],"external_identifier":"347161090","description":[{"value":"Sonora","locale":"es_ES"}],"type_lookup":"721"}ONEabyjr4emj4vyki ENTITY{"identifier":"Pack","name":[{"value":"Pack","locale":"es_ES"}],"external_identifier":"347032090","description":[{"value":"Pack","locale":"es_ES"}],"type_lookup":"753"}ONEae4o73en25sd76 ENTITY{"identifier":"4:3","name":[{"value":"4:3","locale":"es_ES"}],"external_identifier":"370979090","description":[{"value":"4:3","locale":"es_ES"}],"type_lookup":"149"}ONEaey7kvbq7vrkue ENTITY{"identifier":"DVD","name":[{"value":"DVD","locale":"es_ES"}],"external_identifier":"347033090","description":[{"value":"DVD","locale":"es_ES"}],"type_lookup":"755"}ONEagoti3evaosg2o ENTITY{"identifier":"Blanco y Negro","name":[{"value":"Blanco y Negro","locale":"es_ES"}],"external_identifier":"392207090","description":[{"value":"Blanco y Negro","locale":"es_ES"}],"type_lookup":"714"}ONEah7rn2znp2hhks ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}ONEajz3vfesa4dl3s STRINGReacondicionados - Electrónica999.19641834013 +es_ES Reacondicionados 97.000 +es_ESElectrónica999.51569013 +es_ESElectrónicaNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A379518234876651600054791 +es_ES$TD SYNNEX SPAIN SLnCALLE ACER 30,32-08038 BARCELONA - BARCELONA (ESPAñA)  +es_ESFitbit Versa 2 NFC Negro/Aluminio Negro Smartwatch (Reacondicionado casi a estrenar) +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.2EMBALAJE POCO DETERIORADOdFitbit Versa 2 NFC Negro/Aluminio Negro SmartwatchFitbit Versa 2, mucho más que un reloj: es el smartwatch deportivo que ha sido diseñado para ayudarte a maximizar tu día a día y mejorar tu salud y forma física.Fitbit Versa 2 aúna un diseño espectacular con su capacidad de mejora de tu calidad de vida, con su pantalla AMOLED con modo siempre encendido y su nuevo procesador para una experiencia más fluida. Es el smartwatch ideal para la salud y la forma física, análisis continuo del ritmo cardíaco, puntuación del sueño, cientos de apps para personalizarlo a tu gusto y sacarle el máximo partido.Funciones: Spotify (requiere suscripción), control por voz, puntuación del sueño, notificaciones, Fitbit Pay, monitorización continua de ritmo cardíaco, análisis de la actividad y el sueño, monitorización de salud femenina, sesiones de respiración, más de 15 modos de ejercicio y Smarttrack.Acelerómetro de tres ejes, Monitor óptico de ritmo cardiaco, Altímetro, Sensor de luz ambiental, Motor de vibración, WiFi, Sensor SpO2, Bluetooth, NFC y Micrófono4Sumergible hasta 50 metrosLa batería de Versa 2 dura más de 5 días, por lo que podrás monitorizar todo lo que haces, día y nocheContenido de la caja: Fitbit Versa 2 con correa clásica (en talla S y L) y cable de cargaA37951823129742056 FITBIT +es_ES FITBIT4876651600054791 +es_ES$TD SYNNEX SPAIN SLnCALLE ACER 30,32-08038 BARCELONA - BARCELONA (ESPAñA) 998.00055 +es_ES Telefonia móvil998.00118 +es_ESElectrónica998 +es_ES@Jerarquía de Ficha de ProductosMYOC26FB507BKBK +es_ESFitbit Versa 2 NFC Negro/Aluminio Negro Smartwatch (Reacondicionado casi a estrenar)FB507BKBK +es_ESFitbit Versa 2 NFC Negro/Aluminio Negro Smartwatch (Reacondicionado casi a estrenar) +es_ESLos reacondicionados casi a estrenar son productos que tienen la caja abierta pero están en perfecto estado. Consulta condiciones y más información de productos reacondicionados. Descripción del producto original, puede haber cambios en los accesorios o características.2EMBALAJE POCO DETERIORADOdFitbit Versa 2 NFC Negro/Aluminio Negro SmartwatchFitbit Versa 2, mucho más que un reloj: es el smartwatch deportivo que ha sido diseñado para ayudarte a maximizar tu día a día y mejorar tu salud y forma física.Fitbit Versa 2 aúna un diseño espectacular con su capacidad de mejora de tu calidad de vida, con su pantalla AMOLED con modo siempre encendido y su nuevo procesador para una experiencia más fluida. Es el smartwatch ideal para la salud y la forma física, análisis continuo del ritmo cardíaco, puntuación del sueño, cientos de apps para personalizarlo a tu gusto y sacarle el máximo partido.Funciones: Spotify (requiere suscripción), control por voz, puntuación del sueño, notificaciones, Fitbit Pay, monitorización continua de ritmo cardíaco, análisis de la actividad y el sueño, monitorización de salud femenina, sesiones de respiración, más de 15 modos de ejercicio y Smarttrack.Acelerómetro de tres ejes, Monitor óptico de ritmo cardiaco, Altímetro, Sensor de luz ambiental, Motor de vibración, WiFi, Sensor SpO2, Bluetooth, NFC y Micrófono4Sumergible hasta 50 metrosLa batería de Versa 2 dura más de 5 días, por lo que podrás monitorizar todo lo que haces, día y nocheContenido de la caja: Fitbit Versa 2 con correa clásica (en talla S y L) y cable de carga calificacion1Acalificacion2Acalificacion3E5calificacion4VVcalificacion5EScalificacion63N00pler4twpwa2rdqph5nvda77tclsk +ONEa6rza5nkmhli46 ENTITY{"identifier":"g","name":[{"value":"g","locale":"es_ES"}],"external_identifier":"347187090","description":[{"value":"g","locale":"es_ES"}],"type_lookup":"206"}MANYabmfo2f5qlh4ow ENTITY {"identifier":"Bluetooth","name":[{"value":"Bluetooth","locale":"es_ES"}],"external_identifier":"348707090","description":[{"value":"Bluetooth","locale":"es_ES"}],"type_lookup":"185","glossary":{"term":[{"value":"Bluetooth","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Estándar de comunicación mediante ondas de radio. Permite la conexión inalámbrica con el ordenador u otros dispositivos que se encuentren en la misma habitación.","locale":"es_ES"}],"identifier":"5908","name":[{"value":"BLUETOOTH","locale":"es_ES"}],"external_identifier":"599958054"}} {"identifier":"Wi-Fi","name":[{"value":"Wi-Fi","locale":"es_ES"}],"external_identifier":"348939090","description":[{"value":"Wi-Fi","locale":"es_ES"}],"type_lookup":"185","glossary":{"term":[{"value":"Wi-Fi","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Tecnología para la conexión en red de dispositivos (ordenadores, smartphones, impresoras, TV, etc.) sin necesidad de cables. También llamado 802.11 a, b, g, n. en referencia a la normativa técnica aplicable. Este sistema emplea ondas de radio en las bandas de 2.4 GHz y/o 5 GHz y su alcance permite dar cobertura a una vivienda de tamaño medio.","locale":"es_ES"}],"identifier":"21652","name":[{"value":"WI-FI","locale":"es_ES"}],"external_identifier":"598684054"}} {"identifier":"NFC","name":[{"value":"NFC","locale":"es_ES"}],"external_identifier":"348997090","description":[{"value":"NFC","locale":"es_ES"}],"type_lookup":"185","glossary":{"term":[{"value":"NFC","locale":"es_ES"}],"media_objects":[],"description":[{"value":"Near field communication (NFC) es una tecnología de comunicación inalámbrica, de corto alcance y alta frecuencia que permite el intercambio de datos entre dispositivos. Entre otras cosas ,permite realizar pagos con el móvil o compartir información acercando la tapa del teléfono a un dispositivo destinado a tal efecto, como con las tarjetas sin contacto típicas de los autobuses urbanos.","locale":"es_ES"}],"identifier":"13523","name":[{"value":"NFC","locale":"es_ES"}],"external_identifier":"597175054"}}ONEarvjruq4bngole ENTITY{"identifier":"Corning Gorilla Glass","name":[{"value":"Corning Gorilla Glass","locale":"es_ES"}],"external_identifier":"480281090","description":[{"value":"Corning Gorilla Glass","locale":"es_ES"}],"type_lookup":"188"}ONEarydx5zieeedk4 ENTITY{"identifier":"Táctil","name":[{"value":"Táctil","locale":"es_ES"}],"external_identifier":"352567090","description":[{"value":"Táctil","locale":"es_ES"}],"type_lookup":"188"}ONEaymn5tvmeyds3k NUMBER40.0&Telefonia_Movil_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02020-11-15T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02020-11-16T23:00:00.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEate3liesiuooycBOOLEANtrueMANYavq6mln3ba72gy ENTITY{"identifier":"Internet","name":[{"value":"Internet","locale":"es_ES"}],"external_identifier":"1229735090","description":[{"value":"Internet","locale":"es_ES"}],"type_lookup":"10154"}ONEazravcn5thdy6eTIMESTAMP02020-11-13T16:54:07.000ZMANYaqundqcyqbyf5mTIMESTAMP02023-01-24T03:01:45.000ZFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000150688192DVD"2020-11-16T23:00Z"2020-11-15T23:00Z +es_ESCasi a estrenar32681225090Casi a estrenar +es_ESCasi a estrenar2643090$001054789008296 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore H84087e28-f552-43d0-a653-126262b14d05 DELETE<2023-09-02T17:33:06.913017747Z4dataloader-mongo-kafka-job62023-09-02T17:40:22.660914Z(mixer-gtin-agr-kfreeH6a62e8e1-b9c5-4a61-8059-a6dc2b2cd52662023-09-02T17:46:02.731241Z,mixer-gtin-calc-pcsflmHdd64b996-8784-4d73-8699-3ccf8781b19862023-09-02T17:46:03.645455Z,mixer-gtin-calc-pcsflmH9671e51b-4bd1-46c4-871c-e4a8d63524b962023-09-03T02:54:11.261676Z0mixer-product-calc-kfreeH841e9967-70c5-4003-974c-d5b89d298d7a<2024-01-19T11:18:27.699513339Z$mixer-xsell-mixtriHbeac310d-6db9-481a-ae9e-1beaa137353a62024-01-19T11:18:27.913927Z4mixer-packing-units-mixtriHb7cf357a-2cb7-439e-882f-8e15b1c459c262024-01-19T11:18:29.924185Z.mixer-offer-badge-mixbiHb15cf7d3-5af2-489c-b78d-66e62411525162024-01-19T11:21:27.804648Z.mixer-offer-badge-mixbiH65db8e6b-ad81-4736-bc6b-8f8641f8f7ce8ϢcLoffer(A41376740).publish_ends_extendedIVA02IGIC91 +08539001015340747364001018COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001015301808539002"2021-10-07T22:00Z0196010191392Blancos +es_ESBlancosBlancos +es_ESBlancos Blanco +es_ES Blanco347181090 +es_ES Blanco600036054737 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png +es_ESCOLOR_BLANCO +es_ESColor Blanco Blanco +es_ES Blanco0(2021-11-18T13:20:15Z +es_ESCAMISETA158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0000196010191392$000001519626200002TRADICIONAL +es_ESCOLOR_BLANCO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA03/201808/29/737_5_.png2401813809176896471056NAPAPIJRImarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/05/19/2/00001305192/00001305192784mM1011.jpg +es_ESNapapijri +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41376740 +es_ESCamisetas999.39090685013 +es_ESCamisetas 19.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN6236071600538405 +es_ES4VF APPAREL ESPAÑA, S.L.U.CALLE JOAN MIRO,19-21.PLANTA BAJA,.-08005 BARCELONA - BARCELONA (ESPAñA)  +es_ESXCamiseta de mujer cuello redondo manga corta +es_ESCamiseta corta de mujer cuello redondo de manga corta con logo en el pecho.A41376740896471056NAPAPIJRI +es_ESNAPAPIJRI6236071600538405 +es_ES4VF APPAREL ESPAÑA, S.L.U.CALLE JOAN MIRO,19-21.PLANTA BAJA,.-08005 BARCELONA - BARCELONA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSizeNP0A4G71002 +es_ESXCamiseta de mujer cuello redondo manga corta +es_ESXCamiseta de mujer cuello redondo manga corta +es_ESCamiseta corta de mujer cuello redondo de manga corta con logo en el pecho. +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5B00N47925309036 +es_ES36E +es_ESEspañol479448090XS +es_ESXS18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa2ynyjkfoo2woqTIMESTAMP02098-12-31T23:00:01.000ZONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-24T02:59:59.000ZONEafabpb3cbt6g3oTIMESTAMP02022-10-06T22:00:01.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02022-03-07T03:35:31.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 40º","name":[{"value":"Lavar máximo 40º","locale":"es_ES"}],"external_identifier":"350583090","description":[{"value":"Lavar máximo 40º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxCuarenta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/___94922.png","size":"small"}],"description":[{"value":"Lavar Máximo 40º","locale":"es_ES"}],"identifier":"94922","name":[{"value":"LAVARMAXCUARENTA","locale":"es_ES"}],"external_identifier":"600207054"}}{"identifier":"Secadora a temperatura mínima","name":[{"value":"Secadora a temperatura mínima","locale":"es_ES"}],"external_identifier":"484903090","description":[{"value":"Secadora a temperatura mínima","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"Planchado max 130º","name":[{"value":"Planchado max 130º","locale":"es_ES"}],"external_identifier":"484896090","description":[{"value":"Planchado max 130º","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No lavar en seco","name":[{"value":"No lavar en seco","locale":"es_ES"}],"external_identifier":"373231090","description":[{"value":"No lavar en seco","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No lavar en seco","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/NO_RENDER02/201205/09/30230_1_.png","size":"small"}],"description":[{"value":"No limpieza en seco","locale":"es_ES"}],"identifier":"30230","name":[{"value":"NO_LAVAR_EN_SECO","locale":"es_ES"}],"external_identifier":"10707268054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisetas","name":[{"value":"Camisetas","locale":"es_ES"}],"external_identifier":"372161090","description":[{"value":"Camisetas","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"},"adbyfb4jfvuv5k":100.0}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001519626200002(2022-03-07T03:35:31Z(2022-10-06T22:00:01Z(2022-09-24T02:59:59Z$001015301808539002001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore002Hd8bf3002-183c-4e98-8d92-c766d3643591 DELETE<2023-09-02T17:30:56.511787766Z4dataloader-mongo-kafka-job62023-09-02T17:31:08.664763Z(mixer-gtin-agr-kfreeH9cc13646-2c30-41a7-b129-0e4e422f4c3962023-09-02T17:32:51.914827Z,mixer-gtin-calc-pcsflmH557aa520-38b9-4f82-9cfc-cc832d6a29b262023-09-02T17:32:56.323653Z,mixer-gtin-calc-pcsflmH686a2c13-9057-4d02-a160-ce73327b774d62023-09-03T02:55:43.868617Z0mixer-product-calc-kfreeHb9a00dab-db70-4968-9500-d25575300f6d<2024-01-19T11:18:25.915141204Z$mixer-xsell-mixtriH737456f1-75f8-4029-9c8c-286497ae370762024-01-19T11:18:25.950844Z4mixer-packing-units-mixtriH3cee4ece-8419-4272-87f0-861cbe02b29f62024-01-19T11:18:29.936627Z.mixer-offer-badge-mixbiHd5fac602-f9c0-435f-b1b2-7e51b50333a762024-01-19T11:21:27.807011Z.mixer-offer-badge-mixbiH3f15deb0-f778-492c-bbcd-17b82936306e8ϢcIVA02IGIC90"2011-12-14T23:00Z +3445900102023-03-22T03:10:37.950Z02591344911001412COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001025941234459 &includeAsWebNovelty +es_ESNovedadDVD"2011-12-14T23:00Z2259412344594"2011-12-14T23:00Z84273287551390(2012-02-15T12:57:42Z +es_ES*LIONEL ATWILL:EL DOCT +es_ESCine274983090Cine395ML +es_ESml +1.0008427328755139$00000000010268758624014109905818823780564ABSOLUTE DISTRIBUTION S.L. +es_ES,Absolute Distribución +es_ESClásico999.54232013 +es_ESClásico +6.000 +es_ESCine999.54215013 +es_ESCineNN +es_ESCine274983090Cine395A48987856257121600571984 +es_ES6ABSOLUTE DISTRIBUTION, S.L.tCALLE PUIGCERDA,124-08019 BARCELONA - BARCELONA (ESPAñA)  +es_ES0Pack Lionel Atwill (DVD)A48987856257121600571984 +es_ES6ABSOLUTE DISTRIBUTION, S.L.tCALLE PUIGCERDA,124-08019 BARCELONA - BARCELONA (ESPAñA) 998.00080 +es_ESCine998.00079 +es_ESCine998 +es_ES@Jerarquía de Ficha de Productos LASV03 +es_ES0Pack Lionel Atwill (DVD) +es_ES0Pack Lionel Atwill (DVD) +calificacion1ANcalificacion2Ecalificacion3M5calificacion4VVcalificacion5AD06pler4twpwa2rdqpsq2nbutanwi3sONEa2wkf4iqk324hsBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02012-02-15T13:19:08.000ZONEafabpb3cbt6g3oTIMESTAMP02016-07-14T22:00:00.000ZONEapruxddhqugapwBOOLEAN +falseONEapuaxkclolc2qcTIMESTAMP02012-02-15T13:19:08.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE6ONEa2x4yaxk3sajg2 STRING4M.CURTIZ,W.NIGHT,G.WAGGNERONEa4vh5lymazgkpc STRINGN[{"locale":"es_ES","value":"CLASICOS"}]ONEa7efot6m2c2lag STRINGDSONEaagfg5vkt4qsn4 ENTITY{"identifier":"Sonora","name":[{"value":"Sonora","locale":"es_ES"}],"external_identifier":"347161090","description":[{"value":"Sonora","locale":"es_ES"}],"type_lookup":"721"}ONEabyjr4emj4vyki ENTITY{"identifier":"Pack","name":[{"value":"Pack","locale":"es_ES"}],"external_identifier":"347032090","description":[{"value":"Pack","locale":"es_ES"}],"type_lookup":"753"}ONEae4o73en25sd76 ENTITY{"identifier":"Pantalla panorámica","name":[{"value":"Pantalla panorámica","locale":"es_ES"}],"external_identifier":"350486090","description":[{"value":"Pantalla panorámica","locale":"es_ES"}],"type_lookup":"149"}ONEaey7kvbq7vrkue ENTITY{"identifier":"DVD","name":[{"value":"DVD","locale":"es_ES"}],"external_identifier":"347033090","description":[{"value":"DVD","locale":"es_ES"}],"type_lookup":"755"}ONEagoti3evaosg2o ENTITY{"identifier":"Color","name":[{"value":"Color","locale":"es_ES"}],"external_identifier":"347162090","description":[{"value":"Color","locale":"es_ES"}],"type_lookup":"714"}ONEah7rn2znp2hhks ENTITY{"identifier":"Sí","name":[{"value":"Sí","locale":"es_ES"}],"external_identifier":"347407090","description":[{"value":"Sí","locale":"es_ES"}],"type_lookup":"144"}ONEajz3vfesa4dl3s STRINGONEa2x4yaxk3sajg2 STRINGBESTSELLER WHOLESALE SPAIN,S.L. +es_ESRGabardina de mujer manga larga con lazada +es_ESGabardina midi con botones centrales, tejido suave, dos bolsillos y lazada ajustable.A42158956392181056VERO MODA +es_ESVERO MODA0502534 +es_ES>BESTSELLER WHOLESALE SPAIN,S.L.998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize10256042 +es_ESRGabardina de mujer manga larga con lazada +es_ESRGabardina de mujer manga larga con lazada +es_ESGabardina midi con botones centrales, tejido suave, dos bolsillos y lazada ajustable. calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5Bcalificacion61200N47931509042 +es_ES42E +es_ESEspañol479445090XL +es_ESXL18171618090Fabricante +Tallapz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa2ynyjkfoo2woqTIMESTAMP02098-12-31T23:00:01.000ZONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEAN +falseONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02018-12-31T23:00:01.000ZONEafabpb3cbt6g3oTIMESTAMP02022-08-30T22:00:01.000ZONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-01-28T03:41:56.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY +{"identifier":"Lavar a máquina a 30º","name":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"external_identifier":"20550267090","description":[{"value":"Lavar a máquina a 30º","locale":"es_ES"}],"type_lookup":"1584"}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}{"identifier":"Puede limpiarse en seco","name":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"external_identifier":"4197325090","description":[{"value":"Puede limpiarse en seco","locale":"es_ES"}],"type_lookup":"1584"} {"identifier":"No usar secadora","name":[{"value":"No usar secadora","locale":"es_ES"}],"external_identifier":"347671090","description":[{"value":"No usar secadora","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"No usar secadora","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___35917O1.png","size":"small"}],"description":[{"value":"No utilizar secadora","locale":"es_ES"}],"identifier":"35917","name":[{"value":"NO_USAR_SECADORA","locale":"es_ES"}],"external_identifier":"599260054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEabf2vvifj26pzi ENTITY{"identifier":"Midi","name":[{"value":"Midi","locale":"es_ES"}],"external_identifier":"9612160090","description":[{"value":"Midi","locale":"es_ES"}],"type_lookup":"2507"}ONEac5swxsdtmjapu ENTITY{"identifier":"Gabardinas y Chubasqueros","name":[{"value":"Gabardinas y Chubasqueros","locale":"es_ES"}],"external_identifier":"2682024090","description":[{"value":"Gabardinas y Chubasqueros","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}MANYagio3trrjaqhgg ENTITY{"identifier":"Sintético","name":[{"value":"Sintético","locale":"es_ES"}],"external_identifier":"477968090","description":[{"value":"Sintético","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Abrigos","name":[{"value":"Abrigos","locale":"es_ES"}],"external_identifier":"2700610090","description":[{"value":"Abrigos","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Poliéster","name":[{"value":"Poliéster","locale":"es_ES"}],"external_identifier":"344749090","description":[{"value":"Poliestere","locale":"it_IT"},{"value":"Polyester","locale":"en_GB"},{"value":"Poliéster","locale":"es_ES"},{"value":"Polyester","locale":"fr_FR"},{"value":"Poliéster","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001523291000005(2022-01-28T03:41:56Z(2022-08-30T22:00:01Z(2018-12-31T23:00:01Z$001029350101811005001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore005H46915b29-ebb4-47ab-bfd8-166f2855b2a3 DELETE<2023-09-02T17:18:34.340981340Z4dataloader-mongo-kafka-job62023-09-02T17:18:46.455500Z(mixer-gtin-agr-kfreeHad2673d4-f710-493e-bdc8-a49647e8d93562023-09-02T17:18:51.812013Z,mixer-gtin-calc-pcsflmHa9d6f0e3-7a55-483f-8d43-724d2da127c862023-09-02T17:18:52.910006Z,mixer-gtin-calc-pcsflmH20f4c9f3-746f-48af-9481-0d11caa18f8d62023-09-03T02:46:17.133776Z0mixer-product-calc-kfreeHda1a7ab7-f2db-44d2-b3d1-7576b53eefda<2024-01-19T11:18:15.154482211Z$mixer-xsell-mixtriH746c7f3a-5426-4489-9a51-774a64ab9fea62024-01-19T11:18:15.198422Z4mixer-packing-units-mixtriH20d2f560-70b2-4171-9fc0-630ccc38aacd62024-01-19T11:18:30.520970Z.mixer-offer-badge-mixbiHfbd81b54-422e-4aa8-803b-14a0b7c4f5e562024-01-19T11:21:27.890786Z.mixer-offer-badge-mixbiH26466166-8cce-4013-9ee5-9f21b0669e2c8ϢcLoffer(A41129595).publish_ends_extendedIVA02IGIC91 +00239001019341417891001302COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001019330200239044&includeAsWebNovelty +es_ESNovedadDVD +Rojos +es_ES +Rojos +Rojos +es_ES +RojosTeja +es_ESTeja475791090 +es_ESTeja599999054 +62211 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___62211O1.png +es_ESCOLOR_TEJA +es_ESColor TejaTeja +es_ESTeja0(2022-01-24T14:04:37Z +es_ES*BLUS FTSIA MC FTSIA T158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401811518933$000001518391670044TRADICIONAL +es_ESCOLOR_TEJA +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/22/___62211O1.png2401811518933127553056 LLOYDSmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/8/00001269358/00001269358120mM1011.jpg +es_ESLloyd's +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN001019317104776158 +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A41129595 +es_ES,Camisas, Blusas y Tops999.39090684013 +es_ES,Camisas, Blusas y Tops 17.000 +es_ESRopa999.39072551013 +es_ESRopa +1.000 +es_ESModa mujer999.39072442013 +es_ESModa mujerNNN0931030 +es_ESDZHEJIANG AMP ORIENT IMP&EXP.CO LTD +es_ESBBlusa troquelada de 100% algodón +es_ESBlusa troquelada de manga corta con cierre de botones. Es un blusa ligera y femenina confeccionada en tejido de 100% algodón. Es una blusa de calidad y estilo atemporal con la que marcarás estilo vayas a donde vayas.BModelo: 178 de altura y talla 040A41129595127553056LLOYD'S +es_ESLLOYD'S5475121600931030 +es_ESDZHEJIANG AMP ORIENT IMP&EXP.CO LTDdCALLE TAIAN ROAD.,NO 1-310052 HANGZHOU - (CHINA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos +colorfashionSize22S4327 +es_ESBBlusa troquelada de 100% algodón +es_ESBBlusa troquelada de 100% algodón9999999.000 +es_ESBlusa troquelada de manga corta con cierre de botones. Es un blusa ligera y femenina confeccionada en tejido de 100% algodón. Es una blusa de calidad y estilo atemporal con la que marcarás estilo vayas a donde vayas.BModelo: 178 de altura y talla 040 +calificacion1Acalificacion2Acalificacion3RPcalificacion4VVcalificacion5AA00N47932709044 +es_ES44E +es_ESEspañol47932709044 +es_ES44477062090Español +Talla peohixr7rbw25wpz3c2qg46aax5qpler4twpwa2rdqphm44qlzhmwa2ypaxawji3i4mkoqpzemnwoecgod3uONEadxazarzusz3teBOOLEAN +falseONEatos7dqm35n3ma NUMBER9999999Comunes_ISS.SPEC_SECONDARY_TEMPLATEONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEAN +falseONEae4bi37uqkffjcTIMESTAMP02022-09-26T07:36:41.000ZONEafabpb3cbt6g3oTIMESTAMP02022-09-27T07:36:41.000ZONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02022-03-22T05:16:42.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEMANYa2hzkuh27pdfr2 ENTITY {"identifier":"Lavar máximo 30º","name":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"external_identifier":"344723090","description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"LavarMaxTreinta","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51640O1.png","size":"small"}],"description":[{"value":"Lavar máximo 30º","locale":"es_ES"}],"identifier":"51640","name":[{"value":"LAVARMAXTREINTA","locale":"es_ES"}],"external_identifier":"599743054"}}{"identifier":"No usar lejía","name":[{"value":"No usar lejía","locale":"es_ES"}],"external_identifier":"344724090","description":[{"value":"No usar lejía","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"NoUsarLejía","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100622/___51313O1.jpg","size":"small"}],"description":[{"value":"No usar lejía.","locale":"es_ES"}],"identifier":"51313","name":[{"value":"NOUSARLEJIA","locale":"es_ES"}],"external_identifier":"599720054"}} {"identifier":"Planchado max 110º","name":[{"value":"Planchado max 110º","locale":"es_ES"}],"external_identifier":"344725090","description":[{"value":"Planchado max 110º","locale":"es_ES"}],"type_lookup":"1584","glossary":{"term":[{"value":"PlanchadoCientoDiez","locale":"es_ES"}],"media_objects":[{"media_type":"IMAGE","url":"https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100617/___32851O1.png","size":"small"}],"description":[{"value":"Planchado máximo 110º","locale":"es_ES"}],"identifier":"32851","name":[{"value":"PLANCHADOCIENTODIEZ","locale":"es_ES"}],"external_identifier":"599166054"}}MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEa4urgt4zxudifc ENTITY{"identifier":"Liso","name":[{"value":"Liso","locale":"es_ES"}],"external_identifier":"2696256090","description":[{"value":"Liso","locale":"es_ES"}],"type_lookup":"2504"}ONEac5swxsdtmjapu ENTITY{"identifier":"Blusas","name":[{"value":"Blusas","locale":"es_ES"}],"external_identifier":"2682030090","description":[{"value":"Blusas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Mujer","name":[{"value":"Mujer","locale":"es_ES"}],"external_identifier":"344721090","description":[{"value":"Mujer","locale":"es_ES"}],"type_lookup":"1575"}ONEafhirsddl7decs ENTITY{"identifier":"Corta","name":[{"value":"Corta","locale":"es_ES"}],"external_identifier":"347646090","description":[{"value":"Corta","locale":"es_ES"}],"type_lookup":"1597"}MANYagio3trrjaqhgg ENTITY{"identifier":"100% Algodón","name":[{"value":"100% Algodón","locale":"es_ES"}],"external_identifier":"32382944090","description":[{"value":"100% Algodón","locale":"es_ES"}],"type_lookup":"1633"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Camisas, Blusas y Tops","name":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"external_identifier":"2700640090","description":[{"value":"Camisas, Blusas y Tops","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"en_GB"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Cotone","locale":"it_IT"},{"value":"Cotton","locale":"en_GB"},{"value":"Algodón","locale":"es_ES"},{"value":"Coton","locale":"fr_FR"},{"value":"Algodão","locale":"pt_PT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2022MANYaukbggaussh3qe ENTITY{"identifier":"TM1","name":[{"value":"TM1","locale":"es_ES"}],"external_identifier":"42106688090","description":[{"value":"Boho Collection","locale":"es_ES"}],"type_lookup":"2502"}ONEaumavohvmjmvoo ENTITY{"identifier":"CM10","name":[{"value":"CM10","locale":"es_ES"}],"external_identifier":"42106684090","description":[{"value":"Arid Land","locale":"es_ES"}],"type_lookup":"2667090"}Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001518391670044(2022-03-22T05:16:42Z(2022-09-27T07:36:41Z(2022-09-26T07:36:41Z$001019330200239044001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore044H82f4c300-4679-4477-8c71-9bf4cb28c465 DELETE<2023-09-02T17:27:54.634511022Z4dataloader-mongo-kafka-job62023-09-02T17:28:03.703741Z(mixer-gtin-agr-kfreeHe198d147-b311-4e19-a5d3-c3e9e61f974c62023-09-02T17:28:22.522592Z,mixer-gtin-calc-pcsflmH71dfff02-a007-4812-8774-95284d9841c262023-09-02T17:28:27.210723Z,mixer-gtin-calc-pcsflmH0aed74d2-5859-4b2f-ba1c-68b48a1cb7f362023-09-02T22:16:30.590694Z0mixer-product-calc-kfreeHfeb3957e-c49b-4421-aab3-69f76ec210ff<2024-01-19T11:16:58.378543326Z$mixer-xsell-mixtriH6af872b5-5ebf-48cc-afee-dc188fa5e2c162024-01-19T11:16:58.507707Z4mixer-packing-units-mixtriH95eb9bd4-23cf-447d-88e2-b52d34c5070c62024-01-19T11:18:30.726708Z.mixer-offer-badge-mixbiHac6984c5-302d-4d01-b294-4541680c555b62024-01-19T11:21:27.895451Z.mixer-offer-badge-mixbiH08eca0fd-461b-4bad-b7c5-f7df1c3294ef8Ϣcn +$+ +}& \ No newline at end of file diff --git a/src/test/resources/avro-complex-data/complex-avro-3.avro b/src/test/resources/avro-complex-data/complex-avro-3.avro new file mode 100644 index 00000000..bf35ea94 --- /dev/null +++ b/src/test/resources/avro-complex-data/complex-avro-3.avro @@ -0,0 +1,8080 @@ +Objavro.schema{"type":"record","name":"MixerOfferEvent","namespace":"es.eci.firefly.avro.mixer.event","fields":[{"name":"business_event_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"business_object","type":{"type":"record","name":"MixerOffer","namespace":"es.eci.firefly.avro.mixer.model","fields":[{"name":"applied_taxes","type":["null",{"type":"array","items":{"type":"record","name":"AppliedTaxes","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer","fields":[{"name":"type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.AppliedTaxes"}}],"default":null},{"name":"availability_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"availability_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":{"type":"record","name":"Product","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer","fields":[{"name":"additional_product_descriptions","type":["null",{"type":"array","items":{"type":"record","name":"ProductAdditionalDescription","fields":[{"name":"end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductAdditionalDescriptionType","io.confluent.connect.avro.Enum.VARIETY":"VARIETY","io.confluent.connect.avro.Enum.VARIETY_STORE":"VARIETY_STORE","io.confluent.connect.avro.Enum.OTHER":"OTHER","io.confluent.connect.avro.Enum.ARTICLE":"ARTICLE","io.confluent.connect.avro.Enum.TEMPORAL":"TEMPORAL","io.confluent.connect.avro.Enum.TICKET":"TICKET"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductAdditionalDescriptionType"}},{"name":"value","type":["null",{"type":"array","items":{"type":"record","name":"I18nText","fields":[{"name":"locale","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductAdditionalDescription"}}],"default":null},{"name":"badges","type":["null",{"type":"array","items":{"type":"record","name":"Badge","fields":[{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null",{"type":"record","name":"Glossary","fields":[{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"media_objects","type":["null",{"type":"array","items":{"type":"record","name":"MediaObject","fields":[{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"media_category_order","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"media_category_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"media_type","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.MediaObjectType","io.confluent.connect.avro.Enum.AUDIO":"AUDIO","io.confluent.connect.avro.Enum.IMAGE":"IMAGE","io.confluent.connect.avro.Enum.VIDEO":"VIDEO","io.confluent.connect.avro.Enum.DOCUMENT":"DOCUMENT","io.confluent.connect.avro.Enum.LINK":"LINK"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.MediaObjectType"}},{"name":"size","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"tags","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"url","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.MediaObject"}}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"term","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Glossary"}],"default":null},{"name":"icon","type":["null","MediaObject"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Badge"}}],"default":null},{"name":"bar_code_variants","type":["null",{"type":"array","items":{"type":"record","name":"BarCodeVariant","fields":[{"name":"date_created_procurement","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gtin","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_main","type":["null","boolean"],"default":null},{"name":"promotional_end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"promotional_start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BarCodeVariant"}}],"default":null},{"name":"basic_color","type":["null",{"type":"record","name":"Color","fields":[{"name":"color_code","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"color_description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Color"}],"default":null},{"name":"brand","type":["null",{"type":"record","name":"Brand","fields":[{"name":"external_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_eci_brand","type":["null","boolean"],"default":null},{"name":"media_objects","type":["null",{"type":"array","items":"MediaObject"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"url_links","type":["null",{"type":"array","items":{"type":"record","name":"BrandSiteLink","fields":[{"name":"site","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"url","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BrandSiteLink"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Brand"}],"default":null},{"name":"calculated_badges","type":["null",{"type":"array","items":{"type":"record","name":"CalculatedBadge","fields":[{"name":"center_value","type":["null",{"type":"array","items":{"type":"record","name":"PackingUnitsBadge","fields":[{"name":"center","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PackingUnitsBadge"}}],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.CalculatedBadge"}}],"default":null},{"name":"canonical_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"categories","type":["null",{"type":"array","items":{"type":"record","name":"Category","fields":[{"name":"classifications","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"has_more_direct_children","type":["null","boolean"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"metadata","type":["null",{"type":"record","name":"Metadata","fields":[{"name":"is_publish","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Metadata"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"order_in_parent","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"parent_category","type":["null","Category"],"default":null},{"name":"type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.CategoryType","io.confluent.connect.avro.Enum.CD":"CD","io.confluent.connect.avro.Enum.CG":"CG","io.confluent.connect.avro.Enum.I":"I","io.confluent.connect.avro.Enum.L":"L","io.confluent.connect.avro.Enum.LC":"LC","io.confluent.connect.avro.Enum.LE":"LE","io.confluent.connect.avro.Enum.LM":"LM","io.confluent.connect.avro.Enum.LP":"LP","io.confluent.connect.avro.Enum.LS":"LS","io.confluent.connect.avro.Enum.MM":"MM","io.confluent.connect.avro.Enum.MP":"MP","io.confluent.connect.avro.Enum.N":"N","io.confluent.connect.avro.Enum.PP":"PP","io.confluent.connect.avro.Enum.PT":"PT","io.confluent.connect.avro.Enum.R":"R"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.CategoryType"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Category"}}],"default":null},{"name":"center_packing_units","type":["null",{"type":"array","items":{"type":"record","name":"CenterPackingUnits","fields":[{"name":"center_id","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"units_by_center","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.CenterPackingUnits"}}],"default":null},{"name":"color","type":["null","Color"],"default":null},{"name":"cross_selling","type":["null",{"type":"array","items":"BarCodeVariant"}],"default":null},{"name":"cross_selling_product_ids","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"customised_request","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_created_catalog","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"depth","type":["null",{"type":"record","name":"QuantitativeValue","fields":[{"name":"unit_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"unit_text","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"value","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.QuantitativeValue"}],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"description_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"digital_store","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"edition_type","type":["null",{"type":"record","name":"LookupTable","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.LookupTable"}],"default":null},{"name":"edition_types","type":["null",{"type":"array","items":"LookupTable"}],"default":null},{"name":"energy_rating","type":["null",{"type":"record","name":"EnergyRating","fields":[{"name":"classification","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.EnergyRating"}],"default":null},{"name":"environment_signal","type":["null",{"type":"record","name":"EnvironmentSignal","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.EnvironmentSignal"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gift_card_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gross_volume","type":["null","QuantitativeValue"],"default":null},{"name":"gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"h1_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"has_complete_documentation","type":["null","boolean"],"default":null},{"name":"has_own_pum","type":["null","boolean"],"default":null},{"name":"height","type":["null","QuantitativeValue"],"default":null},{"name":"highlighted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"image_color","type":["null",{"type":"record","name":"ImageColor","fields":[{"name":"mode","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":{"type":"array","items":"I18nText"}},{"name":"ratio","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"url","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ImageColor"}],"default":null},{"name":"internal_gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"is_best_sellers_excluded","type":["null","boolean"],"default":null},{"name":"is_comparable","type":["null","boolean"],"default":null},{"name":"is_digital","type":["null","boolean"],"default":null},{"name":"is_eci_express","type":["null","boolean"],"default":null},{"name":"is_eci_express_exclusive","type":["null","boolean"],"default":null},{"name":"is_followed","type":["null","boolean"],"default":null},{"name":"is_indexed","type":["null","boolean"],"default":null},{"name":"is_infinite_stock","type":["null","boolean"],"default":null},{"name":"is_luxury","type":["null","boolean"],"default":null},{"name":"is_soldable_without_image","type":["null","boolean"],"default":null},{"name":"is_variant_of","type":["null","Product"],"default":null},{"name":"is_weight_scale","type":["null","boolean"],"default":null},{"name":"keyword_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"legislation","type":["null",{"type":"array","items":{"type":"record","name":"Legislation","fields":[{"name":"applicable_regulation","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"product_type","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"security_information","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Legislation"}}],"default":null},{"name":"license","type":["null","LookupTable"],"default":null},{"name":"main_category","type":["null","Category"],"default":null},{"name":"manufacturer","type":["null",{"type":"record","name":"Organization","fields":[{"name":"description","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"postal_address","type":["null",{"type":"record","name":"PostalAddress","fields":[{"name":"street_address","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PostalAddress"}],"default":null},{"name":"telephone","type":["null",{"type":"record","name":"Telephone","fields":[{"name":"number","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Telephone"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Organization"}],"default":null},{"name":"max_weight","type":["null","QuantitativeValue"],"default":null},{"name":"min_weight","type":["null","QuantitativeValue"],"default":null},{"name":"model_detail","type":["null",{"type":"record","name":"ModelDetail","fields":[{"name":"model_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"web_model_description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"web_model_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ModelDetail"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"offers","type":["null",{"type":"array","items":{"type":"record","name":"Offer","fields":[{"name":"applied_taxes","type":["null",{"type":"array","items":"AppliedTaxes"}],"default":null},{"name":"availability_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"availability_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":"Product"}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_deleted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_recoded","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_point","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_type_badges","type":["null",{"type":"record","name":"DeliveryTypes","fields":[{"name":"is_eci_express","type":["null","boolean"],"default":null},{"name":"is_eci_pickup","type":["null","boolean"],"default":null},{"name":"is_home_delivery","type":["null","boolean"],"default":null},{"name":"is_internet_exclusive","type":["null","boolean"],"default":null},{"name":"is_sts_pickup","type":["null","boolean"],"default":null},{"name":"sts_companies","type":["null",{"type":"array","items":"Organization"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.DeliveryTypes"}],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"financing_data","type":["null",{"type":"record","name":"FinancingData","fields":[{"name":"end_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"grace_period","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"has_calculator","type":["null","boolean"],"default":null},{"name":"is_no_interest","type":["null","boolean"],"default":null},{"name":"monthly_payments","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"number_payments","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"start_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"total_amount","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type","type":["null","LookupTable"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.FinancingData"}],"default":null},{"name":"good_types","type":["null",{"type":"array","items":{"type":"record","name":"GoodType","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.GoodType"}}],"default":null},{"name":"has_european_conformity_certification","type":["null","boolean"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_non_technological","type":["null","boolean"],"default":null},{"name":"is_publish","type":["null","boolean"],"default":null},{"name":"is_return_allowed","type":["null","boolean"],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_searchable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null",{"type":"record","name":"ProductVariant","fields":[{"name":"additional_product_descriptions","type":["null",{"type":"array","items":"ProductAdditionalDescription"}],"default":null},{"name":"badges","type":["null",{"type":"array","items":"Badge"}],"default":null},{"name":"bar_code_variants","type":["null",{"type":"array","items":"BarCodeVariant"}],"default":null},{"name":"basic_color","type":["null","Color"],"default":null},{"name":"calculated_badges","type":["null",{"type":"array","items":"CalculatedBadge"}],"default":null},{"name":"color","type":["null","Color"],"default":null},{"name":"customised_request","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_created_catalog","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"depth","type":["null","QuantitativeValue"],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"digital_store","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"edition_type","type":["null","LookupTable"],"default":null},{"name":"edition_types","type":["null",{"type":"array","items":"LookupTable"}],"default":null},{"name":"energy_rating","type":["null","EnergyRating"],"default":null},{"name":"environment_signal","type":["null","EnvironmentSignal"],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"gross_volume","type":["null","QuantitativeValue"],"default":null},{"name":"gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"has_complete_documentation","type":["null","boolean"],"default":null},{"name":"has_own_pum","type":["null","boolean"],"default":null},{"name":"height","type":["null","QuantitativeValue"],"default":null},{"name":"highlighted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"image_color","type":["null","ImageColor"],"default":null},{"name":"internal_gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"is_best_sellers_excluded","type":["null","boolean"],"default":null},{"name":"is_comparable","type":["null","boolean"],"default":null},{"name":"is_digital","type":["null","boolean"],"default":null},{"name":"is_eci_express","type":["null","boolean"],"default":null},{"name":"is_eci_express_exclusive","type":["null","boolean"],"default":null},{"name":"is_infinite_stock","type":["null","boolean"],"default":null},{"name":"is_luxury","type":["null","boolean"],"default":null},{"name":"is_soldable_without_image","type":["null","boolean"],"default":null},{"name":"is_variant_of","type":["null","Product"],"default":null},{"name":"is_weight_scale","type":["null","boolean"],"default":null},{"name":"license","type":["null","LookupTable"],"default":null},{"name":"manufacturer","type":["null","Organization"],"default":null},{"name":"max_weight","type":["null","QuantitativeValue"],"default":null},{"name":"min_weight","type":["null","QuantitativeValue"],"default":null},{"name":"model_detail","type":["null","ModelDetail"],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"offers","type":["null",{"type":"array","items":"Offer"}],"default":null},{"name":"pantone","type":["null","LookupTable"],"default":null},{"name":"piece_weight","type":["null","QuantitativeValue"],"default":null},{"name":"presentation_details","type":["null",{"type":"record","name":"PresentationDetails","fields":[{"name":"format","type":["null",{"type":"record","name":"Format","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Format"}],"default":null},{"name":"freshness","type":["null",{"type":"record","name":"Freshness","fields":[{"name":"freshness_days","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"is_alive","type":["null","boolean"],"default":null},{"name":"is_consum_day","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Freshness"}],"default":null},{"name":"is_panification_product","type":["null","boolean"],"default":null},{"name":"package_unit","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"presentation","type":["null",{"type":"record","name":"Presentation","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Presentation"}],"default":null},{"name":"quantity","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PresentationDetails"}],"default":null},{"name":"previous_gtins","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"priority_number","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"product_description","type":["null",{"type":"array","items":{"type":"record","name":"I18nProductDescription","fields":[{"name":"locale","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"value","type":["null",{"type":"array","items":{"type":"record","name":"ProductDescription","fields":[{"name":"name","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"value","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductDescription"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nProductDescription"}}],"default":null},{"name":"purchase_management_stock","type":["null",{"type":"record","name":"PurchaseManagementStock","fields":[{"name":"classifications","type":["null",{"type":"array","items":{"type":"record","name":"Classification","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"value","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Classification"}}],"default":null},{"name":"management_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PurchaseManagementStock"}],"default":null},{"name":"range","type":["null",{"type":"record","name":"Range","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer.features","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.features.Range"}],"default":null},{"name":"related_services","type":["null",{"type":"array","items":{"type":"record","name":"SignalService","fields":[{"name":"mode","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"name","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SignalService"}}],"default":null},{"name":"sale_type","type":["null","LookupTable"],"default":null},{"name":"service_agreement_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"sizes","type":["null",{"type":"array","items":{"type":"record","name":"SizeInfo","fields":[{"name":"main_size","type":["null",{"type":"record","name":"Size","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"size_type","type":["null",{"type":"record","name":"SizeType","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SizeType"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Size"}],"default":null},{"name":"manufacturer_size","type":["null","Size"],"default":null},{"name":"name","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SizeInfo"}}],"default":null},{"name":"special_handling_type","type":["null",{"type":"record","name":"SpecialHandlingType","fields":[{"name":"is_alcohol","type":["null","boolean"],"default":null},{"name":"is_preparation_required","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SpecialHandlingType"}],"default":null},{"name":"special_merchandise_indicator","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"specific_attribute_groups","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"specific_attributes","type":["null",{"type":"array","items":{"type":"record","name":"SpecificAttributes","fields":[{"name":"attributes","type":["null",{"type":"array","items":{"type":"record","name":"Attribute","fields":[{"name":"cardinality","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.AttributeCardinality","io.confluent.connect.avro.Enum.ONE":"ONE","io.confluent.connect.avro.Enum.MANY":"MANY"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.AttributeCardinality"}},{"name":"is_i18n","type":"boolean"},{"name":"name","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"values","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Attribute"}}],"default":null},{"name":"group_name","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"group_type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.GroupType","io.confluent.connect.avro.Enum.SPEC_STORE":"SPEC_STORE","io.confluent.connect.avro.Enum.SPEC_SECONDARY_TEMPLATE":"SPEC_SECONDARY_TEMPLATE"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.GroupType"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SpecificAttributes"}}],"default":null},{"name":"target_market","type":["null",{"type":"record","name":"TargetMarket","fields":[{"name":"age_from","type":["null","QuantitativeValue"],"default":null},{"name":"age_to","type":["null","QuantitativeValue"],"default":null},{"name":"gender_segmentation","type":["null",{"type":"array","items":{"type":"record","name":"GenderSegmentation","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"glossary","type":["null","Glossary"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"type_lookup","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.GenderSegmentation"}}],"default":null},{"name":"recommended_age","type":["null","QuantitativeValue"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.TargetMarket"}],"default":null},{"name":"time_restrictions","type":["null",{"type":"record","name":"TimeRestriction","fields":[{"name":"is_alcohol","type":["null","boolean"],"default":null},{"name":"is_bread","type":["null","boolean"],"default":null},{"name":"is_cooled","type":["null","boolean"],"default":null},{"name":"is_frozen","type":["null","boolean"],"default":null},{"name":"is_required_preparation","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.TimeRestriction"}],"default":null},{"name":"transport_details","type":["null",{"type":"record","name":"TransportDetails","fields":[{"name":"bulky_description","type":["null","LookupTable"],"default":null},{"name":"is_bulky","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.TransportDetails"}],"default":null},{"name":"unique_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"width","type":["null","QuantitativeValue"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariant"}],"default":null},{"name":"launch_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"origin","type":["null",{"type":"record","name":"Origin","fields":[{"name":"identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Origin"}],"default":null},{"name":"publish_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"publish_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"refurbishment_level","type":["null","LookupTable"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":{"type":"record","name":"Seller","fields":[{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Seller"}},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type_reference","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"volume_limit","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Offer"}}],"default":null},{"name":"pack_products","type":["null",{"type":"array","items":{"type":"record","name":"Bundle","fields":[{"name":"is_linkable","type":["null","boolean"],"default":null},{"name":"product","type":"Product"},{"name":"quantity","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Bundle"}}],"default":null},{"name":"pack_type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType","io.confluent.connect.avro.Enum.COLLECTION":"COLLECTION","io.confluent.connect.avro.Enum.AMBIENT":"AMBIENT","io.confluent.connect.avro.Enum.COORDINATED":"COORDINATED","io.confluent.connect.avro.Enum.LOTE":"LOTE","io.confluent.connect.avro.Enum.CONFIGURABLE":"CONFIGURABLE","io.confluent.connect.avro.Enum.FABRICANTE":"FABRICANTE"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType"}],"default":null},{"name":"pantone","type":["null","LookupTable"],"default":null},{"name":"piece_weight","type":["null","QuantitativeValue"],"default":null},{"name":"presentation_details","type":["null","PresentationDetails"],"default":null},{"name":"previous_gtins","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"priority_number","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"product_description","type":["null",{"type":"array","items":"I18nProductDescription"}],"default":null},{"name":"product_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"product_sorting_details","type":["null",{"type":"record","name":"ProductSortingDetails","fields":[{"name":"brand_sorting","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"category_sorting","type":["null",{"type":"array","items":{"type":"record","name":"ProductCategorySorting","fields":[{"name":"category","type":"Category"},{"name":"sort","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductCategorySorting"}}],"default":null},{"name":"size_sorting","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductSortingDetails"}],"default":null},{"name":"product_variants","type":["null",{"type":"array","items":"ProductVariant"}],"default":null},{"name":"provider","type":["null",{"type":"record","name":"Provider","fields":[{"name":"brand","type":["null","Brand"],"default":null},{"name":"description","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"postal_address","type":["null","PostalAddress"],"default":null},{"name":"telephone","type":["null","Telephone"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Provider"}],"default":null},{"name":"purchase_management_stock","type":["null","PurchaseManagementStock"],"default":null},{"name":"range","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.features.Range"],"default":null},{"name":"related_cross_sell_product_ids","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"related_services","type":["null",{"type":"array","items":"SignalService"}],"default":null},{"name":"robots_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"sale_type","type":["null","LookupTable"],"default":null},{"name":"service_agreement_type","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"sizes","type":["null",{"type":"array","items":"SizeInfo"}],"default":null},{"name":"special_handling_type","type":["null","SpecialHandlingType"],"default":null},{"name":"special_merchandise_indicator","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"specific_attribute_groups","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"specific_attributes","type":["null",{"type":"array","items":"SpecificAttributes"}],"default":null},{"name":"sub_brand","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"target_market","type":["null","TargetMarket"],"default":null},{"name":"time_restrictions","type":["null","TimeRestriction"],"default":null},{"name":"title_seo","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"transport_details","type":["null","TransportDetails"],"default":null},{"name":"type","type":["null",{"type":"record","name":"ProductType","fields":[{"name":"description","type":{"type":"array","items":"I18nText"}},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"parent_product_type","type":["null","ProductType"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductType"}],"default":null},{"name":"unique_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"varies_by","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"warranty","type":["null",{"type":"record","name":"Warranty","fields":[{"name":"additional_info","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"description","type":["null",{"type":"array","items":"I18nText"}],"default":null},{"name":"duration","type":["null","QuantitativeValue"],"default":null},{"name":"url","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"urls","type":["null",{"type":"array","items":"I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Warranty"}],"default":null},{"name":"width","type":["null","QuantitativeValue"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.Product"}}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_deleted","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"date_recoded","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_point","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"delivery_type_badges","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.DeliveryTypes"],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"external_identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"financing_data","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.FinancingData"],"default":null},{"name":"good_types","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.GoodType"}],"default":null},{"name":"has_european_conformity_certification","type":["null","boolean"],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_non_technological","type":["null","boolean"],"default":null},{"name":"is_publish","type":["null","boolean"],"default":null},{"name":"is_return_allowed","type":["null","boolean"],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_searchable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariant"],"default":null},{"name":"launch_date","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"mixing_information","type":["null",{"type":"record","name":"MixingInformation","namespace":"es.eci.firefly.avro.mixer.canonical.model.mixer","fields":[{"name":"child_references","type":["null",{"type":"array","items":{"type":"record","name":"SiteOfferReference","namespace":"es.eci.firefly.avro.mixer.canonical.model.site","fields":[{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":{"type":"record","name":"ProductReference","namespace":"es.eci.firefly.avro.mixer.canonical.model.offer","fields":[{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"pack_products","type":["null",{"type":"array","items":{"type":"record","name":"BundleReference","fields":[{"name":"product","type":"ProductReference"},{"name":"quantity","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BundleReference"}}],"default":null},{"name":"pack_type","type":["null",{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType","io.confluent.connect.avro.Enum.COLLECTION":"COLLECTION","io.confluent.connect.avro.Enum.AMBIENT":"AMBIENT","io.confluent.connect.avro.Enum.COORDINATED":"COORDINATED","io.confluent.connect.avro.Enum.LOTE":"LOTE","io.confluent.connect.avro.Enum.CONFIGURABLE":"CONFIGURABLE","io.confluent.connect.avro.Enum.FABRICANTE":"FABRICANTE"},"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.PackType"}],"default":null},{"name":"product_id","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"product_variants","type":["null",{"type":"array","items":{"type":"record","name":"ProductVariantReference","fields":[{"name":"bar_code_variants","type":["null",{"type":"array","items":{"type":"record","name":"BarCodeVariantReference","fields":[{"name":"gtin","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_main","type":["null","boolean"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.BarCodeVariantReference"}}],"default":null},{"name":"gtin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"is_variant_of","type":["null","ProductReference"],"default":null},{"name":"offers","type":["null",{"type":"array","items":{"type":"record","name":"OfferReference","fields":[{"name":"barra","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"bundle_of","type":["null",{"type":"array","items":"ProductReference"}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"good_types","type":["null",{"type":"array","items":{"type":"record","name":"GoodType","namespace":"es.eci.firefly.avro.mixer.canonical.model.mixer","fields":[{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"name","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.mixer.GoodType"}}],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null","ProductVariantReference"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":{"type":"record","name":"SellerReference","fields":[{"name":"identifier","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.SellerReference"}},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.OfferReference"}}],"default":null},{"name":"previous_gtins","type":["null",{"type":"array","items":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"default":null},{"name":"unique_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariantReference"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.offer.ProductReference"}}],"default":null},{"name":"company","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"department","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"family","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"good_types","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.mixer.GoodType"}],"default":null},{"name":"is_salable","type":["null","boolean"],"default":null},{"name":"is_show_offer","type":["null","boolean"],"default":null},{"name":"item_offered","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.ProductVariantReference"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":"es.eci.firefly.avro.mixer.canonical.model.offer.SellerReference"},{"name":"site","type":["null",{"type":"record","name":"SiteInfo","fields":[{"name":"delivery_method","type":["null",{"type":"record","name":"DeliveryMethods","fields":[{"name":"available_centers","type":["null",{"type":"array","items":{"type":"record","name":"Center","fields":[{"name":"code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.Center"}}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.DeliveryMethods"}],"default":null},{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"parent","type":["null",{"type":"record","name":"Site","fields":[{"name":"identifier","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"parent","type":["null","Site"],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.Site"}],"default":null},{"name":"price","type":["null",{"type":"record","name":"Price","fields":[{"name":"available_centers","type":["null",{"type":"array","items":"Center"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.Price"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.SiteInfo"}],"default":null},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.site.SiteOfferReference"}}],"default":null},{"name":"old_reference","type":["null","es.eci.firefly.avro.mixer.canonical.model.site.SiteOfferReference"],"default":null},{"name":"parent_reference","type":["null","es.eci.firefly.avro.mixer.canonical.model.site.SiteOfferReference"],"default":null},{"name":"type","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}}],"connect.name":"es.eci.firefly.avro.mixer.canonical.model.mixer.MixingInformation"}],"default":null},{"name":"name","type":["null",{"type":"array","items":"es.eci.firefly.avro.mixer.canonical.model.offer.I18nText"}],"default":null},{"name":"origin","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.Origin"],"default":null},{"name":"publish_ends","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"publish_starts","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"refurbishment_level","type":["null","es.eci.firefly.avro.mixer.canonical.model.offer.LookupTable"],"default":null},{"name":"sales_reference","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"section","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"seller","type":"es.eci.firefly.avro.mixer.canonical.model.offer.Seller"},{"name":"site","type":"es.eci.firefly.avro.mixer.canonical.model.site.Site"},{"name":"size_code","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"type_reference","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"volume_limit","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.mixer.model.MixerOffer"}},{"name":"date","type":["null","long"],"default":null},{"name":"event_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"event_type","type":{"type":"string","connect.parameters":{"io.confluent.connect.avro.Enum":"es.eci.firefly.avro.commons.event.EventType","io.confluent.connect.avro.Enum.CREATE":"CREATE","io.confluent.connect.avro.Enum.UPDATE":"UPDATE","io.confluent.connect.avro.Enum.UPSERT":"UPSERT","io.confluent.connect.avro.Enum.DELETE":"DELETE","io.confluent.connect.avro.Enum.TIMER":"TIMER"},"connect.name":"es.eci.firefly.avro.commons.event.EventType"}},{"name":"is_priority","type":"boolean","default":false},{"name":"metadata","type":["null",{"type":"array","items":{"type":"record","name":"EventMetadata","namespace":"es.eci.firefly.avro.commons.event","fields":[{"name":"date_created","type":{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}},{"name":"origin","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"trace_id","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"user","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null}],"connect.name":"es.eci.firefly.avro.commons.event.EventMetadata"}}],"default":null},{"name":"process","type":["null",{"type":"string","connect.parameters":{"avro.java.string":"String"},"avro.java.string":"String"}],"default":null},{"name":"partition","type":["null","int"],"default":null},{"name":"offset","type":["null","long"],"default":null},{"name":"timestamp","type":["null","long"],"default":null}],"connect.version":19,"connect.name":"es.eci.firefly.avro.mixer.event.MixerOfferEvent"}LW0\n_IVA02IGIC91 +0730500102023-08-28T17:48:56.076Z004531221207001610VALDEMORO +es_ESVALDEMOROCOMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001004561007305 "2018-09-03T22:00Z2045610073059 Azules +es_ES Azules Azules +es_ES AzulesAzul marino +es_ESAzul marino347633090 +es_ESAzul Marino597289054 +14701 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png +es_ES"COLOR_AZUL_MARINO +es_ES"Color Azul MarinoAzul marino +es_ESAzul marino0(2019-02-06T07:18:32Z +es_ES(MOCHILA MINNIE TOPOS +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401694556381$000000000147193909TRADICIONAL +es_ES"COLOR_AZUL_MARINO +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER/20100719/___14701O1.png2401694556381125393056 DISNEYmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/0S/00/1/0000000S001/0000000S001107mM1011.jpg +es_ES Disney + +es_ESAccesorios999.2682013013 +es_ESAccesorios 18.000 +es_ES$Niña (1-16 años)999.2680817013 +es_ES$Niña (1-16 años) +2.000 +es_ES2014 Infantil999.2680809013 +es_ESInfantil +3.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ESMochilasybolsos999.39090918013 +es_ES"Mochilas y bolsos +3.000 +es_ES +Niña999.39090642013 +es_ES +Niña +1.000 +es_ESAccesorios999.39090603013 +es_ESAccesorios +6.000 +es_ESModa infantil999.39072457013 +es_ESModa infantilNNNN +es_ESModa Infantil997.31845218011 +es_ESModa Infantil +4.000 +es_ES,Licencia, Minnie Mouse997.31494383011 +es_ESMinnie Mouse 32.000 +es_ES0Licencia - Tienda Disney997.2538001011 +es_ES DisneyNNN +es_ESInfantil997.31488290011 +es_ESInfantil +3.000 +es_ES(NO USAR Antigua MODA997.31488237011 +es_ESModa 69.000 +es_ES0Licencia - Tienda Disney997.2538001011 +es_ES DisneyNNN +es_ES,Licencia, Minnie Mouse997.31494383011 +es_ESMinnie Mouse 32.000 +es_ES0Licencia - Tienda Disney997.2538001011 +es_ES DisneyNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A277076885950101600975268 +es_ES8MORATALLA SERRANO, FRANCISCOrCALLE MANUEL BROSETA,1-46960 ALDAYA - VALENCIA (ESPAñA)  +es_ESnMochila de niña Disney con topos y estampado de Minnie +es_ESMochila en azul marino Disney con topos y estampado de Minnie. Tiene solapa y doble cierre: ajustable de cordón y magnético. La mochila lleva un bolsillo exterior con solapa y parche con mensaje en tono rojo. Asas de tela ajustables.A27707688125393056DISNEY-DTR +es_ESDISNEY-DTR5950101600975268 +es_ESNMORATALLA SERRANO, FRANCISCO_recargaNFTrCALLE MANUEL BROSETA,1-46960 ALDAYA - VALENCIA (ESPAñA) 998.00195 +es_ESModa998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de Productos 92MN02 +es_ESnMochila de niña Disney con topos y estampado de Minnie +es_ESnMochila de niña Disney con topos y estampado de Minnie +es_ESMochila en azul marino Disney con topos y estampado de Minnie. Tiene solapa y doble cierre: ajustable de cordón y magnético. La mochila lleva un bolsillo exterior con solapa y parche con mensaje en tono rojo. Asas de tela ajustables. +calificacion1A1calificacion2Acalificacion3RPcalificacion4VVcalificacion5BM00pler4twpwa2rdqpz3c2qg46aax5qpaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"A156","name":[{"value":"A156","locale":"es_ES"}],"external_identifier":"24400027090","description":[{"value":"Despublicado por el agotador","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-09-09T22:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-09-10T22:00:00.000ZONEajqf5zfv32jtdq NUMBER 555555ONEakzd7vzeui6lmu STRINGDONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02019-01-13T23:00:00.000ZONEate3liesiuooycBOOLEAN +falseFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATE MANYa4ljbqm5nabztw ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEac5swxsdtmjapu ENTITY{"identifier":"Mochilas","name":[{"value":"Mochilas","locale":"es_ES"}],"external_identifier":"484998090","description":[{"value":"Mochilas","locale":"es_ES"}],"type_lookup":"1617"}MANYadla3f5bsg737w ENTITY{"identifier":"Niña","name":[{"value":"Niña","locale":"es_ES"}],"external_identifier":"357131090","description":[{"value":"Niña","locale":"es_ES"}],"type_lookup":"1575"}ONEagr5xh55nzbgcy ENTITY{"identifier":"Accesorios","name":[{"value":"Accesorios","locale":"es_ES"}],"external_identifier":"347895090","description":[{"value":"Accesorios","locale":"es_ES"}],"type_lookup":"1599"}MANYasxdasitnac2owCOMPLEX +{"adoygdonopx3qq":[{"ascegjzrpcrvti":[{"adbyfb4jfvuv5k":100.0,"aydgn5j2m5edgq":{"identifier":"%","name":[{"value":"%","locale":"es_ES"}],"external_identifier":"344726090","description":[{"value":"%","locale":"fr_FR"},{"value":"%","locale":"pt_PT"},{"value":"%","locale":"es_ES"},{"value":"%","locale":"en_GB"}],"type_lookup":"214"},"a6zd77kj2mm2n4":{"identifier":"Algodón","name":[{"value":"Algodón","locale":"es_ES"}],"external_identifier":"344730090","description":[{"value":"Algodón","locale":"es_ES"},{"value":"Algodão","locale":"pt_PT"},{"value":"Coton","locale":"fr_FR"},{"value":"Cotton","locale":"en_GB"},{"value":"Cotone","locale":"it_IT"}],"type_lookup":"1633"}}]}]}MANYatc4u6vijhkdp6 NUMBER2019Moda_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000000000147193909"2019-01-13T23:00ZDVD"2019-09-10T22:00Z"2019-09-09T22:00Z$001004561007305 001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore Hb1c175b3-a2ad-414a-abc4-852140ae4d47 DELETE62023-09-07T15:14:40.363722Z4dataloader-mongo-kafka-job62023-09-07T15:14:49.480355Z(mixer-gtin-agr-kfreeH2d32fc41-270f-4e22-a6f6-08ef8f39183262023-09-07T15:15:01.300536Z,mixer-gtin-calc-pcsflmH5c66a0bb-1d01-42c0-b3ea-d7667f5207d962023-09-07T15:15:10.952488Z,mixer-gtin-calc-pcsflmHdded07c4-91be-4143-b659-3703165ae92962023-09-07T15:15:14.038562Z0mixer-product-calc-kfreeH66d7ccb8-0bfa-45f1-ae80-6396bbdaf825<2024-01-19T11:22:37.562936268Z$mixer-xsell-mixtriH275e86cc-1a5a-453d-8a1e-6d3e38bb780b62024-01-19T11:22:37.720925Z4mixer-packing-units-mixtriH13cfd0e6-090f-41ea-a875-47323dda6f0662024-01-19T11:31:29.084669Z.mixer-offer-badge-mixbiHda675395-b0c6-47c1-a74b-33ac89ef003162024-01-19T11:32:43.926301Z.mixer-offer-badge-mixbiH38e4fb5a-2898-4008-9e45-4d4ce7ed0c188cIVA02IGIC91 +0226800102023-01-27T15:34:20.912Z003331450281001441COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001003344102268070&includeAsWebNovelty +es_ESNovedadDVD Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2019-02-22T11:19:26Z +es_ES"BLUCHER TEXTIL PG +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401695086719$000001472249660070TRADICIONAL +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401695086719129997056 CLARKSmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/69/35/7/00001269357/00001269357628mM1011.jpg +es_ES Clarks +es_ESZapatillas999.39073065013 +es_ESZapatillas +3.000 +es_ESZapatos999.39072678013 +es_ESZapatos +2.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ESZapatos confort999.39073068013 +es_ESZapatos confort +8.000 +es_ESZapatos999.39072678013 +es_ESZapatos +2.000 +es_ESModa hombre999.39072454013 +es_ESModa hombreNNN +es_ES$Zapatos de confort999.2682185013 +es_ES$Zapatos de confort +6.000 +es_ES"Zapatos de hombre999.2682140013 +es_ES"Zapatos de hombre +2.000 +es_ES2014 Zapatos999.2682136013 +es_ESZapatos +4.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ESZapatillas999.2682177013 +es_ESZapatillas +1.000 +es_ES"Zapatos de hombre999.2682140013 +es_ES"Zapatos de hombre +2.000 +es_ES2014 Zapatos999.2682136013 +es_ESZapatos +4.000 +es_ESModa999.53895013 +es_ESModaNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A277559645217221600454462 +es_ESBC & J CLARK INTERNATIONAL LIMITEDCALLE CL FUENCARRAL.121. 6ªPL,..-28010 MADRID - MADRID (ESPAñA)  +es_ES|Zapatillas deportivas de hombre Clarks en textil de color azul +es_ESZapatillas deportivas fabricadas en material textil. De la colección Cloud Steppers, incorporan materiales Premium de gran flexibilidad y suela ultraligera en goma EVA.A27755964129997056 CLARKS +es_ES CLARKS5217221600454462 +es_ESBC & J CLARK INTERNATIONAL LIMITEDCALLE CL FUENCARRAL.121. 6ªPL,..-28010 MADRID - MADRID (ESPAñA) 998.00196 +es_ESZapatería998.00193 +es_ESModa998 +es_ES@Jerarquía de Ficha de ProductosfashionSizeSTEP URBAN MIX. +es_ES|Zapatillas deportivas de hombre Clarks en textil de color azul +es_ES|Zapatillas deportivas de hombre Clarks en textil de color azul +es_ESZapatillas deportivas fabricadas en material textil. De la colección Cloud Steppers, incorporan materiales Premium de gran flexibilidad y suela ultraligera en goma EVA. calificacion1A1calificacion2Ocalificacion3RPcalificacion4VVcalificacion5Bcalificacion6CA0047931109041 +es_ES41E +es_ESEspañol4793990907 +es_ES7477062090Español +Tallapler4twpwa2rdqphm44qlzhmwa2ypwe2kceprh5w3apaxawji3i4mkoqONEa2wkf4iqk324hsBOOLEAN +falseONEa3frrndcro7fwwBOOLEAN +falseONEa3l5iwa4qvnwkgBOOLEANtrueONEa4qcksvnig5nwy ENTITY{"identifier":"011","name":[{"value":"011","locale":"es_ES"}],"external_identifier":"233768090","description":[{"value":"Gestión Automática - Despublica publicadas sin stock ECI","locale":"es_ES"}],"type_lookup":"10110"}ONEa5c22lw7zunsbkBOOLEAN +falseONEaaiiovqahsixwqBOOLEANtrueONEae4bi37uqkffjcTIMESTAMP02019-03-11T23:00:00.000ZONEafabpb3cbt6g3oTIMESTAMP02019-09-21T07:28:02.000ZONEajqf5zfv32jtdq NUMBER 555555ONEapruxddhqugapwBOOLEANtrueONEapuaxkclolc2qcTIMESTAMP02019-02-19T23:00:00.000ZONEate3liesiuooycBOOLEANtrueFechas_WWW_ISS.SPEC_SECONDARY_TEMPLATEONEa6omxp2z4a5xk6 ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYa7jpc7s7go77wi ENTITY{"identifier":"Otros materiales","name":[{"value":"Otros materiales","locale":"es_ES"}],"external_identifier":"349472090","description":[{"value":"Otros materiales","locale":"es_ES"}],"type_lookup":"1633"}ONEa7xqyqnqtfqof6 ENTITY{"identifier":"Sandalias","name":[{"value":"Sandalias","locale":"es_ES"}],"external_identifier":"462621090","description":[{"value":"Sandalias","locale":"es_ES"}],"type_lookup":"1620"}ONEairuz7tgcgcbee ENTITY{"identifier":"mm","name":[{"value":"mm","locale":"es_ES"}],"external_identifier":"347200090","description":[{"value":"mm","locale":"es_ES"}],"type_lookup":"204"}MANYaks4jlgaxtjowg ENTITY{"identifier":"Goma","name":[{"value":"Goma","locale":"es_ES"}],"external_identifier":"477871090","description":[{"value":"Goma","locale":"es_ES"}],"type_lookup":"1633"}ONEalnwwhqri3drmq ENTITY{"identifier":"Cordones","name":[{"value":"Cordones","locale":"es_ES"}],"external_identifier":"386376090","description":[{"value":"Cordones","locale":"es_ES"}],"type_lookup":"1574"}MANYamzex7cmn57eei ENTITY{"identifier":"Hombre","name":[{"value":"Hombre","locale":"es_ES"}],"external_identifier":"344773090","description":[{"value":"Hombre","locale":"es_ES"}],"type_lookup":"1575"}ONEaoxempa2cyaedo ENTITY{"identifier":"Flex","name":[{"value":"Flex","locale":"es_ES"}],"external_identifier":"9575231090","description":[{"value":"Flex","locale":"es_ES"}],"type_lookup":"761"}MANYaqmgzyppu6mney ENTITY{"identifier":"Mezcla de fibras","name":[{"value":"Mezcla de fibras","locale":"es_ES"}],"external_identifier":"477893090","description":[{"value":"Mezcla de fibras","locale":"es_ES"}],"type_lookup":"1633"}MANYatxwwl2ksd2bme ENTITY{"identifier":"Primavera-Verano","name":[{"value":"Primavera-Verano","locale":"es_ES"}],"external_identifier":"479799090","description":[{"value":"Primavera-Verano","locale":"es_ES"}],"type_lookup":"1577"}ONEauik4rxccjjcze ENTITY{"identifier":"Redonda","name":[{"value":"Redonda","locale":"es_ES"}],"external_identifier":"3020307090","description":[{"value":"Redonda","locale":"es_ES"}],"type_lookup":"1612"}MANYaukl3rq7vmbfcy ENTITY{"identifier":"Zapatillas","name":[{"value":"Zapatillas","locale":"es_ES"}],"external_identifier":"349403090","description":[{"value":"Zapatillas","locale":"es_ES"}],"type_lookup":"1620"}MANYauqqk66n7fk6uu ENTITY{"identifier":"Sintético","name":[{"value":"Sintético","locale":"es_ES"}],"external_identifier":"477968090","description":[{"value":"Sintético","locale":"es_ES"}],"type_lookup":"1633"}ONEauur46vhpycka4 ENTITY{"identifier":"Zapatos hombre","name":[{"value":"Zapatos hombre","locale":"es_ES"}],"external_identifier":"347770090","description":[{"value":"Zapatos hombre","locale":"es_ES"}],"type_lookup":"1611"}MANYaxr5m2ljibnmui NUMBER2019Zapateria_ISS.SPEC_SECONDARY_TEMPLATE +es_ESNo voluminoso347190090No voluminoso +es_ESNo voluminoso401$000001472249660070"2019-02-19T23:00Z(2019-09-21T07:28:02Z"2019-03-11T23:00Z$001003344102268070001001 +es_ES*El Corte Ingles, S.A.2eciStore_MercanciaGeneraleciStore070Hfefa1715-9df1-436b-bdc4-da03b7ae66ec DELETE62023-09-07T15:15:11.032068Z4dataloader-mongo-kafka-job62023-09-07T15:15:14.687876Z(mixer-gtin-agr-kfreeH0a892411-419d-40d0-9091-f5b504206b2062023-09-07T15:15:26.917074Z,mixer-gtin-calc-pcsflmHe920470e-5815-49f0-848c-0ffa9134a72a62023-09-07T15:15:36.949884Z,mixer-gtin-calc-pcsflmHabbddf0f-4b41-4d61-87a1-ea6f5c014c0662023-09-07T15:15:38.842560Z0mixer-product-calc-kfreeH48575178-8f10-4c61-9a23-81721a57117c<2024-01-19T11:22:38.192807298Z$mixer-xsell-mixtriH66923002-5e6a-488a-a329-55a2157b1ded62024-01-19T11:22:38.320413Z4mixer-packing-units-mixtriHddc3e82e-24b4-49ce-80db-c0c46fe8a9ae62024-01-19T11:31:29.186023Z.mixer-offer-badge-mixbiH3e266743-f1f2-4abe-a4e7-60f61a893aa962024-01-19T11:32:44.010798Z.mixer-offer-badge-mixbiH88953012-cef3-412b-83db-69066180a3568cIVA02IGIC91 +0103600102023-01-14T06:42:47.833Z034331633845001421COMPRA EN FIRME +es_ESCOMPRA EN FIRMESTERLING +es_ESSTERLING$001034342101036046&includeAsWebNovelty +es_ESNovedadDVD Azules +es_ES Azules Azules +es_ES AzulesAzul +es_ESAzul347189090 +es_ESAzul598455054 +15915 +IMAGE +smallhttps://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png +es_ESCOLOR_AZUL +es_ESColor AzulAzul +es_ESAzul0(2019-04-02T18:19:17Z +es_ES*CAMISETA TIRANTES COM +es_ES,Mercancía general ECI274979090,Mercancía general ECI395ML +es_ESml +0.0002401685955896$000001468132550046MUESTRARIO +es_ESCOLOR_AZUL +1.000https://sgfm.elcorteingles.es/SGFM/dctm/NO_RENDER02/201205/10/___15915O3.png2401685955896123768056BOOMERANGmarcasUrlLogo +IMAGE mediumhttps://sgfm.elcorteingles.es/SGFM/dctm/MEDIA02/CONTENIDOS/201411/07/1254468469_3_.jpg +es_ESBoomerang +es_ESRopa Deportiva999.53664013 +es_ESRopa deportiva +8.000 +es_ESDeportes999.53663013 +es_ESDeportesNN +es_ES +Mujer999.17368063013 +es_ES +Mujer +2.000 +es_ESRopa training999.52215013 +es_ESRopa training 20.000 +es_ESFitness999.53701013 +es_ESFitness 17.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES0Ropa para yoga y pilates999.37734565013 +es_ES0Ropa para yoga y pilates +2.000 +es_ESYoga y pilates999.37734563013 +es_ESYoga y pilates 26.000 +es_ESDeportes999.53663013 +es_ESDeportesNNN +es_ESCamisetas999.14619942013 +es_ESCamisetas +6.000 +es_ESRopa deportiva999.12473893013 +es_ESRopa deportiva +1.000 +es_ES +Mujer999.12406166013 +es_ES +Mujer +3.000 +es_ESDeportes999.53663013 +es_ESDeportesNNNN +es_ES,Mercancía general ECI274979090,Mercancía general ECI395A269115950903027 +es_ES