Examples of merge()


Examples of org.apache.cayenne.util.DeepMergeOperation.merge()

                                // often a query will not have any info indicating the
                                // entity type
                                ClassDescriptor descriptor = resolver
                                        .getClassDescriptor(id.getEntityName());

                                it.set(merger.merge(object, descriptor));
                            }
                        }
                    }
                }
            }
View Full Code Here

Examples of org.apache.derby.iapi.sql.execute.ExecAggregator.merge()

      }
    }
    uaIn = (ExecAggregator)(((UserDataValue) aggregatorColumnIn).getObject());
    uaOut = (ExecAggregator)(((UserDataValue) aggregatorColumnOut).getObject());

    uaOut.merge(uaIn);
  }

  //////////////////////////////////////////////////////
  //
  // MISC
View Full Code Here

Examples of org.apache.directory.server.dhcp.options.OptionsField.merge()

                // set (client) host name
                o.add( new HostName( host.getName() ) );

                // add subnet settings
                o.add( new SubnetMask( subnet.getNetmask() ) );
                o.merge( subnet.getOptions() );

                // add the host's options. they override existing
                // subnet options as they take the precedence.
                o.merge( host.getOptions() );
            }
View Full Code Here

Examples of org.apache.flex.forks.velocity.Template.merge()

                velocityContext.put("packageName", info.getPackageName());

                // run the template!
                //long s2 = System.currentTimeMillis();
                //VelocityManager.parseTime += s2 - start;
                template.merge(velocityContext, out);
                //VelocityManager.mergeTime += System.currentTimeMillis() - s2;

                // Normalize line endings as a temporary work around for bug 149821
                String generated = out.toString().replaceAll("\r\n", "\n");
                String filename = writeGenerated(info, generated);
View Full Code Here

Examples of org.apache.hadoop.hive.ql.udf.generic.GenericUDAFEvaluator.merge()

    Object res2 = udafEvaluator2.terminate(agg2);
   
    ObjectInspector finalOutputOi = udafEvaluator2.init(Mode.FINAL, new ObjectInspector[] {partialOutputOi1});
   
    AggregationBuffer agg3 = udafEvaluator2.getNewAggregationBuffer();
    udafEvaluator2.merge(agg3, agg1);
    udafEvaluator2.merge(agg3, agg2);
   
    Object result = udafEvaluator2.terminate(agg3);
   
    LOG.info("result = " + result);
View Full Code Here

Examples of org.apache.hadoop.io.SequenceFile.Sorter.merge()

            s.preserveInput(true);
            s.doSync();
            segmentList.add(i, s);
          }
          segmentStart = finalOut.getPos();
          RawKeyValueIterator kvIter = sorter.merge(segmentList, new Path(getTaskId()));
          SequenceFile.Writer writer = SequenceFile.createWriter(job, finalOut,
                                                                 job.getMapOutputKeyClass(), job.getMapOutputValueClass(),
                                                                 compressionType, codec);
          sorter.writeFile(kvIter, writer);
          //close the file - required esp. for block compression to ensure
View Full Code Here

Examples of org.apache.helix.ZNRecord.merge()

        {
          CreateMode mode = (persistent) ? CreateMode.PERSISTENT : CreateMode.EPHEMERAL;
          if (record.getDeltaList().size() > 0)
          {
            ZNRecord value = new ZNRecord(record.getId());
            value.merge(record);
            client.create(path, value, mode);
          }
          else
          {
            client.create(path, record, mode);
View Full Code Here

Examples of org.apache.helix.messaging.handling.GroupMessageHandler.GroupMessageInfo.merge()

        GroupMessageInfo info = _executor._groupMsgHandler.onCompleteSubMessage(_message);
        if (info != null)
        {
          // TODO: changed to async update
          // group update current state
          Map<PropertyKey, CurrentState> curStateMap = info.merge();
          for (PropertyKey key : curStateMap.keySet())
          {
            accessor.updateProperty(key, curStateMap.get(key));
          }
View Full Code Here

Examples of org.apache.jackrabbit.jcr2spi.state.ItemState.merge()

        } else {
            // was already resolved before -> merge the existing state
            // with the passed state.
            int currentStatus = currentState.getStatus();
            boolean keepChanges = Status.isTransient(currentStatus) || Status.isStale(currentStatus);
            MergeResult mergeResult = currentState.merge(state, keepChanges);
            if (currentStatus == Status.INVALIDATED) {
                currentState.setStatus(Status.EXISTING);
            } else if (mergeResult.modified()) {
                currentState.setStatus(Status.MODIFIED);
            } // else: not modified. just leave status as it is.
View Full Code Here

Examples of org.apache.jackrabbit.mk.api.MicroKernel.merge()

        NodeState oldRoot = store.getRoot();
        NodeState toCommit = editor.editCommit(store, oldRoot, currentRoot);
        setRoot(toCommit);

        try {
            String mergedRevision = kernel.merge(branchRevision, null);
            branchRevision = null;
            currentRoot = null;
            committed = null;
            KernelNodeState committed = new KernelNodeState(kernel, getValueFactory(), "/", mergedRevision);
            return committed;
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.