org.msgpack.value.Value Java Examples
The following examples show how to use
org.msgpack.value.Value.
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: ColumnCaster.java From embulk-parser-jsonl with MIT License | 6 votes |
public static boolean asBoolean(Value value) throws DataException { if (value.isBooleanValue()) { return value.asBooleanValue().getBoolean(); } else if (value.isIntegerValue()) { return LongCast.asBoolean(value.asIntegerValue().asLong()); } else if (value.isFloatValue()) { return DoubleCast.asBoolean(value.asFloatValue().toDouble()); } else if (value.isStringValue()) { return StringCast.asBoolean(value.asStringValue().asString()); } else { return JsonCast.asBoolean(value); } }
Example #2
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visitMap_DropColumns() { PluginTask task = taskFromYamlString( "type: column", "drop_columns:", " - {name: $.json1.k1.k1}", " - {name: $.json1.k2}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .add("json2", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":{"k1":"v"},"k2":{"k2":"v"}} Value k1 = ValueFactory.newString("k1"); Value k2 = ValueFactory.newString("k2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newMap(k1, v), k2, ValueFactory.newMap(k2, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k1\":{}}", visited.toString()); }
Example #3
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visitMap_AddColumns() { PluginTask task = taskFromYamlString( "type: column", "add_columns:", " - {name: $.json1.k3.k3, type: string, default: v}", " - {name: $.json1.k4, src: $.json1.k2}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .add("json2", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":{"k1":"v"},"k2":{"k2":"v"}} Value k1 = ValueFactory.newString("k1"); Value k2 = ValueFactory.newString("k2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newMap(k1, v), k2, ValueFactory.newMap(k2, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k1\":{\"k1\":\"v\"},\"k2\":{\"k2\":\"v\"},\"k3\":{\"k3\":\"v\"},\"k4\":{\"k2\":\"v\"}}", visited.toString()); }
Example #4
Source File: TdWaitOperatorFactory.java From digdag with Apache License 2.0 | 6 votes |
private boolean fetchJobResult(TDJobOperator job) { Optional<ArrayValue> firstRow = pollingRetryExecutor(state, RESULT) .retryUnless(TDOperator::isDeterministicClientException) .withErrorMessage("Failed to download result of job '%s'", job.getJobId()) .run(s -> job.getResult( ite -> ite.hasNext() ? Optional.of(ite.next()) : Optional.absent())); // There must be at least one row in the result for the wait condition to be fulfilled. if (!firstRow.isPresent()) { return false; } ArrayValue row = firstRow.get(); if (row.size() < 1) { throw new TaskExecutionException("Got empty row in result of query"); } Value firstCol = row.get(0); return isTruthy(firstCol); }
Example #5
Source File: JsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
public Value visit(String rootPath, Value value) { if (! shouldVisit(rootPath)) { return value; } if (value == null) { return null; } else if (value.isArrayValue()) { return visitArray(rootPath, value.asArrayValue()); } else if (value.isMapValue()) { return visitMap(rootPath, value.asMapValue()); } else { return value; } }
Example #6
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visitMap_addColumnsUsingBracketNotation() { PluginTask task = taskFromYamlString( "type: column", "add_columns:", " - {name: \"$['json1']['k3']['k3']\", type: string, default: v}", " - {name: \"$['json1']['k4']\", src: \"$['json1']['k2']\"}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .add("json2", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":{"k1":"v"},"k2":{"k2":"v"}} Value k1 = ValueFactory.newString("k1"); Value k2 = ValueFactory.newString("k2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newMap(k1, v), k2, ValueFactory.newMap(k2, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k1\":{\"k1\":\"v\"},\"k2\":{\"k2\":\"v\"},\"k3\":{\"k3\":\"v\"},\"k4\":{\"k2\":\"v\"}}", visited.toString()); }
Example #7
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visitArray_dropColumnsUsingBracketNotation() { PluginTask task = taskFromYamlString( "type: column", "drop_columns:", " - {name: \"$['json1']['k1'][0]['k1']\"}", " - {name: \"$['json1']['k2'][*]\"}"); // ending with [*] is allowed for drop_columns, but not for others Schema inputSchema = Schema.builder() .add("json1", JSON) .add("json2", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":[{"k1":"v"}[,"k2":["v","v"]} Value k1 = ValueFactory.newString("k1"); Value k2 = ValueFactory.newString("k2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newArray(ValueFactory.newMap(k1, v)), k2, ValueFactory.newArray(v, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k1\":[{}],\"k2\":[]}", visited.toString()); }
Example #8
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visitArray_addColumnsUsingBracketNotation() { PluginTask task = taskFromYamlString( "type: column", "add_columns:", " - {name: \"$['json1']['k1'][1]\", src: \"$['json1']['k1'][0]\"}", " - {name: \"$['json1']['k3'][0]['k3']\", type: string, default: v}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .add("json2", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":[{"k1":"v"}],"k2":["v","v"]} Value k1 = ValueFactory.newString("k1"); Value k2 = ValueFactory.newString("k2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newArray(ValueFactory.newMap(k1, v)), k2, ValueFactory.newArray(v, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k1\":[{\"k1\":\"v\"},{\"k1\":\"v\"}],\"k2\":[\"v\",\"v\"],\"k3\":[{\"k3\":\"v\"}]}", visited.toString()); }
Example #9
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visitArray_columnsUsingBracketNotation() { PluginTask task = taskFromYamlString( "type: column", "columns:", " - {name: \"$['json1']['k1'][1]\", src: \"$['json1']['k1'][0]\"}", " - {name: \"$['json1']['k2'][0]\"}", " - {name: \"$['json1']['k3'][0]['k3']\", type: string, default: v}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":[{"k1":"v"},"v"],"k2":["v","v"]} Value k1 = ValueFactory.newString("k1"); Value k2 = ValueFactory.newString("k2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newArray(ValueFactory.newMap(k1, v), v), k2, ValueFactory.newArray(v, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k1\":[{\"k1\":\"v\"}],\"k2\":[\"v\"],\"k3\":[{\"k3\":\"v\"}]}", visited.toString()); }
Example #10
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visit_withDotAndBracket() { PluginTask task = taskFromYamlString( "type: column", "columns:", " - {name: \"$.json1['k_1']\"}", " - {name: \"$.json1['k_1'][0]['k_1']\"}", " - {name: \"$['json1']['k_2']\"}", " - {name: \"$['json1']['k_2']['k_2']\"}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k.1":[{"k.1":"v"}], "k.2":{"k.2":"v"}} Value k1 = ValueFactory.newString("k_1"); Value k2 = ValueFactory.newString("k_2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newArray(ValueFactory.newMap(k1, v)), k2, ValueFactory.newMap(k2, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k_1\":[{\"k_1\":\"v\"}],\"k_2\":{\"k_2\":\"v\"}}", visited.toString()); }
Example #11
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visit_withComplexRename() { PluginTask task = taskFromYamlString( "type: column", "columns:", " - {name: \"$.json1['k____1']\", src: \"$.json1['k.-=+1']\"}", " - {name: \"$.json1['k____1'][0]['k____1']\", src: \"$.json1['k____1'][0]['k.-=+1']\"}", " - {name: \"$['json1']['k_2']\", src: \"$['json1']['k.2']\"}", " - {name: \"$['json1']['k_2']['k_2']\", src: \"$['json1']['k_2']['k.2']\"}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k.1":[{"k.1":"v"}], "k.2":{"k.2":"v"}} Value k1 = ValueFactory.newString("k.-=+1"); Value k2 = ValueFactory.newString("k.2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newArray(ValueFactory.newMap(k1, v)), k2, ValueFactory.newMap(k2, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k____1\":[{\"k____1\":\"v\"}],\"k_2\":{\"k_2\":\"v\"}}", visited.toString()); }
Example #12
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visitMap_columnsUsingBracketNotation() { PluginTask task = taskFromYamlString( "type: column", "columns:", " - {name: \"$['json1']['k1']\"}", " - {name: \"$['json1']['k2']['k2']\"}", " - {name: \"$['json1']['k3']['k3']\", type: string, default: v}", " - {name: \"$['json1']['k4']\", src: \"$['json1']['k2']\"}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":{"k1":"v"},"k2":{"k1":"v","k2":"v"}} Value k1 = ValueFactory.newString("k1"); Value k2 = ValueFactory.newString("k2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newMap(k1, v), k2, ValueFactory.newMap(k2, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k1\":{\"k1\":\"v\"},\"k2\":{\"k2\":\"v\"},\"k3\":{\"k3\":\"v\"},\"k4\":{\"k2\":\"v\"}}", visited.toString()); }
Example #13
Source File: ColumnCaster.java From embulk-parser-jsonl with MIT License | 6 votes |
public static long asLong(Value value) throws DataException { if (value.isBooleanValue()) { return BooleanCast.asLong(value.asBooleanValue().getBoolean()); } else if (value.isIntegerValue()) { return value.asIntegerValue().asLong(); } else if (value.isFloatValue()) { return DoubleCast.asLong(value.asFloatValue().toDouble()); } else if (value.isStringValue()) { return StringCast.asLong(value.asStringValue().asString()); } else { return JsonCast.asLong(value); } }
Example #14
Source File: ColumnCaster.java From embulk-parser-jsonl with MIT License | 6 votes |
public static double asDouble(Value value) throws DataException { if (value.isBooleanValue()) { return BooleanCast.asDouble(value.asBooleanValue().getBoolean()); } else if (value.isIntegerValue()) { return LongCast.asDouble(value.asIntegerValue().asLong()); } else if (value.isFloatValue()) { return value.asFloatValue().toDouble(); } else if (value.isStringValue()) { return StringCast.asDouble(value.asStringValue().asString()); } else { return JsonCast.asDouble(value); } }
Example #15
Source File: MessagePackRecordAccessor.java From fluency with Apache License 2.0 | 6 votes |
@Override public void setTimestamp(long timestamp) { int mapSize = mapValueBytes.map().size(); try (ByteArrayOutputStream output = new ByteArrayOutputStream(mapValueBytes.byteArray().length + 16)) { try (MessagePacker packer = MessagePack.newDefaultPacker(output)) { if (mapValueBytes.map().containsKey(KEY_TIME)) { packer.packMapHeader(mapSize); } else { packer.packMapHeader(mapSize + 1); KEY_TIME.writeTo(packer); packer.packLong(timestamp); } for (Map.Entry<Value, Value> entry : mapValueBytes.map().entrySet()) { packer.packValue(entry.getKey()); packer.packValue(entry.getValue()); } } mapValueBytes = new MapValueBytes(ByteBuffer.wrap(output.toByteArray())); } catch (IOException e) { throw new IllegalStateException("Failed to upsert `time` field", e); } }
Example #16
Source File: ColumnCaster.java From embulk-parser-jsonl with MIT License | 6 votes |
public static Timestamp asTimestamp(Value value, TimestampParser parser) throws DataException { if (value.isBooleanValue()) { return BooleanCast.asTimestamp(value.asBooleanValue().getBoolean()); } else if (value.isIntegerValue()) { return LongCast.asTimestamp(value.asIntegerValue().asLong()); } else if (value.isFloatValue()) { return DoubleCast.asTimestamp(value.asFloatValue().toDouble()); } else if (value.isStringValue()) { return StringCast.asTimestamp(value.asStringValue().asString(), parser); } else { return JsonCast.asTimestamp(value); } }
Example #17
Source File: FluentdIngesterTest.java From fluency with Apache License 2.0 | 6 votes |
@Test void ingestWithoutAck() throws IOException { Ingester ingester = new FluentdIngester(new FluentdIngester.Config(), fluentdSender); ingester.ingest(TAG, ByteBuffer.wrap(DATA)); verify(fluentdSender, times(1)).send(byteBuffersArgumentCaptor.capture()); List<ByteBuffer> byteBuffers = byteBuffersArgumentCaptor.getAllValues().get(0); byte[] ingested = getIngestedData(byteBuffers); MessageUnpacker unpacker = MessagePack.newDefaultUnpacker(ingested); ImmutableArrayValue arrayValue = unpacker.unpackValue().asArrayValue(); assertEquals(3, arrayValue.size()); assertEquals(TAG, arrayValue.get(0).asStringValue().asString()); assertArrayEquals(DATA, arrayValue.get(1).asRawValue().asByteArray()); Map<Value, Value> options = arrayValue.get(2).asMapValue().map(); assertEquals(1, options.size()); assertEquals(DATA.length, options.get(ValueFactory.newString("size")).asIntegerValue().asInt()); }
Example #18
Source File: FluencyTest.java From fluency with Apache License 2.0 | 6 votes |
@ParameterizedTest @MethodSource("sslFlagsProvider") void testWithoutAckResponse(final boolean sslEnabled) throws Throwable { Exception exception = new ConfigurableTestServer(sslEnabled).run( clientSocket -> { MessageUnpacker unpacker = MessagePack.newDefaultUnpacker(clientSocket.getInputStream()); assertEquals(3, unpacker.unpackArrayHeader()); assertEquals("foo.bar", unpacker.unpackString()); ImmutableRawValue rawValue = unpacker.unpackValue().asRawValue(); Map<Value, Value> map = unpacker.unpackValue().asMapValue().map(); assertEquals(1, map.size()); assertEquals(rawValue.asByteArray().length, map.get(KEY_OPTION_SIZE).asIntegerValue().asInt()); unpacker.close(); }, serverPort -> { FluencyBuilderForFluentd builder = new FluencyBuilderForFluentd(); builder.setSslEnabled(sslEnabled); try (Fluency fluency = builder.build(serverPort)) { fluency.emit("foo.bar", new HashMap<>()); } }, 5000); assertNull(exception); }
Example #19
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visit_withColumnNameIncludingSingleQuotes() { PluginTask task = taskFromYamlString( "type: column", "columns:", " - {name: \"$['\\\\'json1']['k1']\"}"); Schema inputSchema = Schema.builder() .add("'json1", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k1":"v"} Value k1 = ValueFactory.newString("k1"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap(k1, v); MapValue visited = subject.visit("$['\\'json1']", map).asMapValue(); assertEquals("{\"k1\":\"v\"}", visited.toString()); }
Example #20
Source File: TestJsonVisitor.java From embulk-filter-column with MIT License | 6 votes |
@Test public void visit_withSingleQuotesAndDoubleQuotes() { PluginTask task = taskFromYamlString( "type: column", "columns:", " - {name: \"$['json1']['k_1']\", src: \"$['json1']['k.1']\"}", " - {name: '$[\"json1\"][\"k_1\"][0][\"k_1\"]', src: '$[\"json1\"][\"k_1\"][0][\"k.1\"]'}", " - {name: '$[\"json1\"][\"k_2\"]', src: '$[\"json1\"][\"k.2\"]'}", " - {name: '$[\"json1\"][\"k_2\"][\"k_2\"]', src: '$[\"json1\"][\"k_2\"][\"k.2\"]'}"); Schema inputSchema = Schema.builder() .add("json1", JSON) .build(); JsonVisitor subject = jsonVisitor(task, inputSchema); // {"k.1":[{"k.1":"v"}], "k.2":{"k.2":"v"}} Value k1 = ValueFactory.newString("k.1"); Value k2 = ValueFactory.newString("k.2"); Value v = ValueFactory.newString("v"); Value map = ValueFactory.newMap( k1, ValueFactory.newArray(ValueFactory.newMap(k1, v)), k2, ValueFactory.newMap(k2, v)); MapValue visited = subject.visit("$['json1']", map).asMapValue(); assertEquals("{\"k_1\":[{\"k_1\":\"v\"}],\"k_2\":{\"k_2\":\"v\"}}", visited.toString()); }
Example #21
Source File: TestColumnCaster.java From embulk-parser-jsonl with MIT License | 5 votes |
@Before public void createResource() { jruby = new ScriptingContainer(); thrown = new DataException("any"); Value[] kvs = new Value[2]; kvs[0] = ValueFactory.newString("k"); kvs[1] = ValueFactory.newString("v"); mapValue = ValueFactory.newMap(kvs); parser = new TimestampParser(jruby, "%Y-%m-%d %H:%M:%S.%N", DateTimeZone.UTC); }
Example #22
Source File: MessagePackDeserializer.java From attic-polygene-java with Apache License 2.0 | 5 votes |
private Object doGuessDeserialize( ModuleDescriptor module, ValueType valueType, Value value ) throws IOException, ClassNotFoundException { switch( value.getValueType() ) { case MAP: MapValue mapValue = value.asMapValue(); Optional<String> typeInfo = mapValue .entrySet().stream() .filter( entry -> entry.getKey().isStringValue() ) .map( entry -> { String key = doDeserialize( module, ValueType.STRING, entry.getKey() ); return new AbstractMap.SimpleImmutableEntry<>( key, entry.getValue() ); } ) .filter( entry -> "_type".equals( entry.getKey() ) ) .findFirst() .map( entry -> doDeserialize( module, ValueType.STRING, entry.getValue() ) ); if( typeInfo.isPresent() ) { StatefulAssociationCompositeDescriptor descriptor = statefulCompositeDescriptorFor( module, typeInfo.get() ); if( descriptor != null ) { return deserializeStatefulAssociationValue( ( (CompositeDescriptor) descriptor ).module(), descriptor.valueType(), mapValue ); } } default: throw new SerializationException( "Don't know how to deserialize " + valueType + " from " + value + " (" + value.getValueType() + ")" ); } }
Example #23
Source File: MessagePackSerializer.java From attic-polygene-java with Apache License 2.0 | 5 votes |
@Override public void serialize( Options options, OutputStream output, @Optional Object object ) { try( MessagePacker packer = MessagePack.newDefaultPacker( output ) ) { Value value = doSerialize( options, object, true ); packer.packValue( value ); packer.flush(); } catch( IOException ex ) { throw new SerializationException( "Unable to serialize " + object, ex ); } }
Example #24
Source File: MessagePackDeserializer.java From attic-polygene-java with Apache License 2.0 | 5 votes |
private Object deserializeStatefulAssociationValue( ModuleDescriptor module, StatefulAssociationValueType<?> valueType, MapValue value ) throws IOException { Map<String, Value> namedValues = value.map().entrySet().stream().map( entry -> { String key = doDeserialize( module, ValueType.STRING, entry.getKey() ); return new AbstractMap.SimpleImmutableEntry<>( key, entry.getValue() ); } ).collect( toMap( HashMap::new ) ); String typeInfo = null; if( namedValues.containsKey( "_type" ) ) { typeInfo = doDeserialize( module, ValueType.STRING, namedValues.get( "_type" ) ); } if( typeInfo != null ) { // TODO What to do with typeInfo? Value or Entity ? StatefulAssociationCompositeDescriptor descriptor = statefulCompositeDescriptorFor( module, typeInfo ); if( descriptor == null ) { throw new SerializationException( "_type: " + typeInfo + " could not be resolved while deserializing " + value ); } valueType = descriptor.valueType(); } ValueBuilder builder = module.instance().newValueBuilderWithState( valueType.primaryType(), propertyFunction( valueType.module(), namedValues ), associationFunction( valueType.module(), namedValues ), manyAssociationFunction( valueType.module(), namedValues ), namedAssociationFunction( valueType.module(), namedValues ) ); return builder.newInstance(); }
Example #25
Source File: MessagePackDeserializer.java From attic-polygene-java with Apache License 2.0 | 5 votes |
private Map<Object, Object> deserializeMap( ModuleDescriptor module, MapType mapType, MapValue value ) throws IOException { Map<Object, Object> map = new LinkedHashMap<>( value.size() ); for( Map.Entry<Value, Value> entry : value.entrySet() ) { Object key = doDeserialize( module, mapType.keyType(), entry.getKey() ); Object val = doDeserialize( module, mapType.valueType(), entry.getValue() ); map.put( key, val ); } return map; }
Example #26
Source File: MessagePackRecordAccessor.java From fluency with Apache License 2.0 | 5 votes |
@Override public String getAsString(String key) { Value value = mapValueBytes.map().get(ValueFactory.newString(key)); if (value == null) { return null; } return value.toString(); }
Example #27
Source File: MessagePackDeserializer.java From attic-polygene-java with Apache License 2.0 | 5 votes |
private Collection<?> deserializeCollection( ModuleDescriptor module, CollectionType collectionType, ArrayValue value ) throws IOException { Collection<?> collection = collectionType.isSet() ? new LinkedHashSet( value.size() ) : new ArrayList( value.size() ); for( Value element : value.list() ) { collection.add( doDeserialize( module, collectionType.collectedType(), element ) ); } return collection; }
Example #28
Source File: TestJsonCast.java From embulk-parser-jsonl with MIT License | 5 votes |
@Before public void createResource() { Value[] kvs = new Value[2]; kvs[0] = ValueFactory.newString("k"); kvs[1] = ValueFactory.newString("v"); value = ValueFactory.newMap(kvs); }
Example #29
Source File: MessagePackDeserializer.java From attic-polygene-java with Apache License 2.0 | 5 votes |
private Function<AssociationDescriptor, Stream<Map.Entry<String, EntityReference>>> namedAssociationFunction( ModuleDescriptor module, Map<String, Value> namedValues ) { return association -> { Map map = doDeserialize( module, ENTITY_REF_MAP_VALUE_TYPE, namedValues.get( association.qualifiedName().name() ) ); return map == null ? Stream.empty() : map.entrySet().stream(); }; }
Example #30
Source File: TdOperatorFactory.java From digdag with Apache License 2.0 | 5 votes |
static Config buildStoreParams(ConfigFactory cf, TDJobOperator j, boolean storeLastResults, TaskState state, DurationInterval retryInterval) { if (storeLastResults) { Config td = cf.create(); List<ArrayValue> results = downloadFirstResults(j, 1, state, RESULT, retryInterval); Map<RawValue, Value> map = new LinkedHashMap<>(); if (!results.isEmpty()) { ArrayValue row = results.get(0); List<String> columnNames = j.getResultColumnNames(); for (int i = 0; i < Math.min(row.size(), columnNames.size()); i++) { map.put(ValueFactory.newString(columnNames.get(i)), row.get(i)); } } MapValue lastResults = ValueFactory.newMap(map); try { td.set("last_results", new ObjectMapper().readTree(lastResults.toJson())); } catch (IOException ex) { throw Throwables.propagate(ex); } return cf.create().set("td", td); } else { return cf.create(); } }