Examples of Stream


Examples of org.librdf.redland.Stream

    return (contains_int != 0);
  }

  public Stream as_stream()
  {
    return new Stream(this.world, core.librdf_model_as_stream(this.object), this);
  }
View Full Code Here

Examples of org.openntf.domino.Stream

  private int getStrPayloadLotus(final Session sess, final String whose) throws IOException {

    int payload = 0;
    File fAux = null;
    Stream str = null;
    try {
      fAux = File.createTempFile("ntfdom", "aux.tmp");
      str = sess.createStream();
      str.open(fAux.getPath(), "LMBCS");
      str.writeText(whose);
      payload = str.getBytes();

    } finally {
      if (str != null)
        str.close();
      if (fAux != null)
        fAux.delete();
    }
    return payload;
  }
View Full Code Here

Examples of org.pentaho.di.trans.step.errorhandling.Stream

    public StepIOMetaInterface getStepIOMeta() {

    StepIOMetaInterface ioMeta = new StepIOMeta(true, true, true, false, !infoSteps.isEmpty(), !targetSteps.isEmpty());
     
      for (RoleStepMeta step : infoSteps) {
        ioMeta.addStream(new Stream(StreamType.INFO, step.getStepMeta(), step.getRoleName(), StreamIcon.INFO, null));
      }
      for (RoleStepMeta step : targetSteps) {
        ioMeta.addStream(new Stream(StreamType.TARGET, step.getStepMeta(), step.getRoleName(), StreamIcon.TARGET, null));
      }
     
      return ioMeta;
    }
View Full Code Here

Examples of org.springframework.xd.dirt.core.Stream

    String streamDeploymentPath = new StreamDeploymentsPath().setStreamName(streamName).setModuleType(moduleType)
        .setModuleLabel(moduleLabel).setModuleSequence(properties.getSequenceAsString())
        .setContainer(this.containerAttributes.getId()).build();

    Module module = null;
    Stream stream = DeploymentLoader.loadStream(client, streamName, streamFactory);
    if (stream != null) {
      ModuleDescriptor descriptor = stream.getModuleDescriptor(moduleLabel);
      module = deployModule(descriptor, properties);

      try {
        // this indicates that the container has deployed the module
        client.create().creatingParentsIfNeeded().withMode(CreateMode.EPHEMERAL).forPath(streamDeploymentPath);
View Full Code Here

Examples of org.springframework.xd.dirt.stream.Stream

    try {
      Stat definitionStat = client.checkExists().forPath(path);
      if (definitionStat != null) {
        byte[] data = client.getData().forPath(path);
        Map<String, String> map = ZooKeeperUtils.bytesToMap(data);
        Stream stream = new Stream(new StreamDefinition(id, map.get("definition")));

        Stat deployStat = client.checkExists().forPath(Paths.build(Paths.STREAM_DEPLOYMENTS, id));
        if (deployStat != null) {
          stream.setStartedAt(new Date(deployStat.getCtime()));
          stream.setStatus(getDeploymentStatus(id));
          return stream;
        }
      }
    }
    catch (Exception e) {
View Full Code Here

Examples of reactor.rx.Stream

            Action<?, ?> rootAction = findOldestUpstream(Action.class);

            if (rootAction.getSubscription() != null
                && PushSubscription.class.isAssignableFrom(rootAction.getSubscription().getClass())) {

              Stream originalStream = ((PushSubscription<?>) rootAction.getSubscription()).getPublisher();
              if(originalStream != null){
                rootAction.cancel();
                originalStream.subscribe(rootAction);
              }

            }
            upstreamSubscription.request(capacity);
          }
View Full Code Here

Examples of storm.trident.Stream

                new Values("the man went to the store and bought some candy", 2l), new Values("four score and seven years ago", 3l),
                new Values("how many apples can you eat", 4l), new Values("to be or not to be the person", 5l));
        spout.setCycle(true);

        TridentTopology topology = new TridentTopology();
        Stream stream = topology.newStream("spout1", spout);

        Fields hdfsFields = new Fields("sentence", "key");

        FileNameFormat fileNameFormat = new DefaultFileNameFormat()
                .withPath("/trident")
                .withPrefix("trident")
                .withExtension(".txt");

        RecordFormat recordFormat = new DelimitedRecordFormat()
                .withFields(hdfsFields);

        FileRotationPolicy rotationPolicy = new FileSizeRotationPolicy(5.0f, FileSizeRotationPolicy.Units.MB);

        HdfsState.Options options = new HdfsState.HdfsFileOptions()
                .withFileNameFormat(fileNameFormat)
                .withRecordFormat(recordFormat)
                .withRotationPolicy(rotationPolicy)
                .withFsUrl(hdfsUrl);

        StateFactory factory = new HdfsStateFactory().withOptions(options);

        TridentState state = stream
                .partitionPersist(factory, hdfsFields, new HdfsUpdater(), new Fields());

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

Examples of vicazh.hyperpool.stream.net.Stream

          connection.wait(3600000);
        } catch (InterruptedException e) {
        }
    }
    connection.getServer().outputstream = null;
    connection.setServer(new Stream((Connection) connection, session
        .getServer()));
    if (outputstream != null)
      outputstream.close();
  }
View Full Code Here

Examples of vicazh.hyperpool.stream.net.Stream

  public String getAddress() {
    return address;
  }

  public OutputStream get(OutputStream outputstream) throws IOException {
    Stream stream = (Stream) super.get(outputstream);
    ((ClientStream) stream.outputstream).head("CONNECT", address,
        "HTTP/1.0");
    ((ClientStream) stream.outputstream).header();
    stream.flush();
    return stream;
  }
View Full Code Here

Examples of vicazh.hyperpool.stream.net.Stream

  public int getPort() {
    return port;
  }

  public OutputStream get(OutputStream outputstream) throws IOException {
    Stream stream = (Stream) super.get(outputstream);
    ((ClientStream) stream.outputstream).head("CONNECT", host + ':' + port,
        "HTTP/1.0");
    ((ClientStream) stream.outputstream).header();
    stream.flush();
    return stream;
  }
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.