Examples of Input


Examples of com.asakusafw.compiler.flow.ExternalIoDescriptionProcessor.Input

        assert processor != null;
        assert importGroup != null;
        assert exportGroup != null;
        List<Input> inputs = Lists.create();
        for (Import model : importGroup) {
            inputs.add(new Input(model.getDescription(), model.getOutputFormatType()));
        }
        List<Output> outputs = Lists.create();
        for (Export model : exportGroup) {
            List<SourceInfo> sources = Lists.create();
            for (Source source : model.getResolvedSources()) {
View Full Code Here

Examples of com.cfinkel.reports.wrappers.Input

    public static Map<Input, Object> convertParameterMapToInputs(Map<String, String[]> parameterMap, Report report) throws InvalidInputException {
        Map<Input,Object> inputMap = new HashMap<Input,Object>();
        // convert map to inputs:
        for (String  key : report.getAllInputs().keySet()) {
            Input input = report.getAllInputs().get(key);
            Object valueObj = parameterMap.get(input.get().getName());

            if (valueObj == null) {
                throw new InvalidInputException("required request not present");
            }
            inputMap.put(input,valueObj);
View Full Code Here

Examples of com.datasalt.pangool.tuplemr.MultipleInputsInterface.Input

   * Defines an input as in {@link PangoolMultipleInputs} using {@link TupleInputFormat}
   *
   * @see PangoolMultipleInputs
   */
  public void addTupleInput(Path path, TupleMapper<ITuple, NullWritable> tupleMapper) {
    multipleInputs.getMultiInputs().add(new Input(path, new TupleInputFormat(), tupleMapper));
  }
View Full Code Here

Examples of com.esotericsoftware.kryo.io.Input

  }

  public Object read (Kryo kryo, Input input, Class type) {
    // The inflater would read from input beyond the compressed bytes if chunked enoding wasn't used.
    InflaterInputStream inflaterStream = new InflaterInputStream(new InputChunked(input, 256), new Inflater(noHeaders));
    return kryo.readObject(new Input(inflaterStream, 256), type, serializer);
  }
View Full Code Here

Examples of com.facebook.presto.client.Input

        root.accept(new Visitor(builder), null);

        ImmutableList.Builder<Input> inputBuilder = ImmutableList.builder();
        for (Map.Entry<TableEntry, Collection<String>> entry : builder.build().asMap().entrySet()) {
            Input input = new Input(entry.getKey().getConnectorId(), entry.getKey().getSchema(), entry.getKey().getTable(), ImmutableList.copyOf(entry.getValue()));
            inputBuilder.add(input);
        }

        return inputBuilder.build();
    }
View Full Code Here

Examples of com.facebook.presto.execution.Input

                        columnMetadata.getName(),
                        columnMetadata.getType().toString(),
                        Optional.fromNullable(SimpleDomain.fromDomain(domain)));
                columnBuilder.add(column);
            }
            Input input = new Input(
                    tableMetadata.getConnectorId(),
                    tableMetadata.getTable().getSchemaName(),
                    tableMetadata.getTable().getTableName(),
                    columnBuilder.build());
            inputBuilder.add(input);
View Full Code Here

Examples of com.facebook.presto.sql.tree.Input

        public PhysicalOperation visitTableCommit(TableCommitNode node, LocalExecutionPlanContext context)
        {
            PhysicalOperation source = node.getSource().accept(this, context);

            OperatorFactory operatorFactory = new TableCommitOperatorFactory(context.getNextOperatorId(), createTableCommitter(node, metadata));
            Map<Symbol, Input> layout = ImmutableMap.of(node.getOutputSymbols().get(0), new Input(0));

            return new PhysicalOperation(operatorFactory, layout, source);
        }
View Full Code Here

Examples of com.google.api.services.prediction.model.Input

    System.exit(1);
  }

  private static void predict(Prediction prediction, String text)
      throws IOException {
    Input input = new Input();
    InputInput inputInput = new InputInput();
    inputInput.setCsvInstance(Collections.<Object> singletonList(text));
    input.setInput(inputInput);
    Output output = prediction.trainedmodels().predict(MODEL_ID, input)
        .execute();
    System.out.println("Text: " + text);
    System.out.println("Predicted language: " + output.getOutputLabel());
  }
View Full Code Here

Examples of com.google.appengine.tools.mapreduce.Input

  }

  private String startStatsJob(int mapShardCount, int reduceShardCount) {
    // (I, K, V, O, R)
    // Input<I>, Input<Entity>, so I=Entity
    Input input = new DatastoreInput("Reading", mapShardCount);

    // Mapper<I,K,V>, Mapper<Entity, String, String>, so I=Entity, K=String, V=String
    Mapper<Entity, String, String> mapper = new ReadingMapper();

    // Reducer<K,V,O>, Reducer<String, String, ReadingHistory>, so K=String, V=String,
View Full Code Here

Examples of com.k42b3.zubat.basic.form.Input

    item.setLayout(new FlowLayout());

    JLabel label = new JLabel(nodeLabel.getTextContent());
    label.setPreferredSize(new Dimension(100, 22));

    Input input = new Input();
    input.setPreferredSize(new Dimension(300, 22));
   
    if(nodeValue != null)
    {
      input.setText(nodeValue.getTextContent());
    }

    if(nodeDisabled != null && nodeDisabled.getTextContent().equals("true"))
    {
      input.setEnabled(false);
    }

    item.add(label);
    item.add(input);
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.