Codota Logo
DistributedPubSubMediator$Put.<init>
Code IndexAdd Codota to your IDE (free)

How to use
akka.cluster.pubsub.DistributedPubSubMediator$Put
constructor

Best Java code snippets using akka.cluster.pubsub.DistributedPubSubMediator$Put.<init> (Showing top 10 results out of 315)

  • Add the Codota plugin to your IDE and get smart completions
private void myMethod () {
ScheduledThreadPoolExecutor s =
  • Codota Iconnew ScheduledThreadPoolExecutor(corePoolSize)
  • Codota IconThreadFactory threadFactory;new ScheduledThreadPoolExecutor(corePoolSize, threadFactory)
  • Codota IconString str;new ScheduledThreadPoolExecutor(1, new ThreadFactoryBuilder().setNameFormat(str).build())
  • Smart code suggestions by Codota
}
origin: eclipse/ditto

private <C extends AbstractConciergeConfigReader> ConciergeRootActor(final C configReader,
    final ActorRef pubSubMediator,
    final AbstractEnforcerActorFactory<C> authorizationProxyPropsFactory,
    final ActorMaterializer materializer) {
  requireNonNull(configReader);
  requireNonNull(pubSubMediator);
  requireNonNull(authorizationProxyPropsFactory);
  requireNonNull(materializer);
  final ActorContext context = getContext();
  final ActorRef conciergeShardRegion =
      authorizationProxyPropsFactory.startEnforcerActor(context, configReader, pubSubMediator);
  retrieveStatisticsDetailsResponseSupplier = RetrieveStatisticsDetailsResponseSupplier.of(conciergeShardRegion,
      ConciergeMessagingConstants.SHARD_REGION, log);
  final ActorRef conciergeForwarder = startChildActor(context, ConciergeForwarderActor.ACTOR_NAME,
      ConciergeForwarderActor.props(pubSubMediator, conciergeShardRegion));
  pubSubMediator.tell(new DistributedPubSubMediator.Put(getSelf()), getSelf());
  pubSubMediator.tell(new DistributedPubSubMediator.Put(conciergeForwarder), getSelf());
  startClusterSingletonActor(context, BatchSupervisorActor.ACTOR_NAME,
      BatchSupervisorActor.props(pubSubMediator, conciergeForwarder));
  final ActorRef healthCheckingActor = startHealthCheckingActor(context, configReader);
  final HttpConfigReader httpConfig = configReader.http();
  bindHttpStatusRoute(healthCheckingActor, httpConfig, materializer);
}
origin: org.eclipse.ditto/ditto-services-thingsearch-updater-actors

        " process events again"));
pubSubMediator.tell(new DistributedPubSubMediator.Put(getSelf()), getSelf());
origin: eclipse/ditto

        " process events again"));
pubSubMediator.tell(new DistributedPubSubMediator.Put(getSelf()), getSelf());
origin: eclipse/ditto

@Override
public void preStart() {
  pubSubMediator.tell(new DistributedPubSubMediator.Put(getSelf()), getSelf());
  pubSubMediator.tell(new DistributedPubSubMediator.Subscribe(BatchExecutionFinished.TYPE, ACTOR_NAME, getSelf()),
      getSelf());
}
origin: eclipse/ditto

private BlockedNamespacesUpdater(final BlockedNamespaces blockedNamespaces, final ActorRef pubSubMediator) {
  this.blockedNamespaces = blockedNamespaces;
  // register self for pub-sub on restart
  pubSubMediator.tell(new Put(getSelf()), getSelf());
  // subscribe to namespace-blocking commands
  pubSubMediator.tell(new DistributedPubSubMediator.Subscribe(BlockNamespace.TYPE, getSelf()), getSelf());
  pubSubMediator.tell(new DistributedPubSubMediator.Subscribe(UnblockNamespace.TYPE, getSelf()), getSelf());
}
origin: eclipse/ditto

  /**
   * Tell PubSubMediator about self so that other actors may send messages here from other cluster nodes.
   *
   * @param self ActorRef of this actor.
   * @param pubSubMediator Akka PubSub mediator.
   */
  private static void putSelfToPubSubMediator(final ActorRef self, final ActorRef pubSubMediator) {
    pubSubMediator.tell(new DistributedPubSubMediator.Put(self), self);
  }
}
origin: eclipse/ditto

private SearchRootActor(final ServiceConfigReader configReader, final ActorRef pubSubMediator,
    final ActorMaterializer materializer) {
  final Config rawConfig = configReader.getRawConfig();
  final CommandListener kamonCommandListener = rawConfig.getBoolean(ConfigKeys.MONITORING_COMMANDS_ENABLED) ?
      new KamonCommandListener(KAMON_METRICS_PREFIX) : null;
  final ConnectionPoolListener kamonConnectionPoolListener =
      rawConfig.getBoolean(ConfigKeys.MONITORING_CONNECTION_POOL_ENABLED) ?
          new KamonConnectionPoolListener(KAMON_METRICS_PREFIX) : null;
  final MongoClientWrapper mongoClientWrapper =
      MongoClientWrapper.newInstance(rawConfig, kamonCommandListener, kamonConnectionPoolListener);
  final StreamMetadataPersistence thingsSyncPersistence =
      MongoSearchSyncPersistence.initializedInstance(THINGS_SYNC_STATE_COLLECTION_NAME, mongoClientWrapper,
          materializer);
  final StreamMetadataPersistence policiesSyncPersistence =
      MongoSearchSyncPersistence.initializedInstance(POLICIES_SYNC_STATE_COLLECTION_NAME, mongoClientWrapper,
          materializer);
  final ActorRef searchActor = initializeSearchActor(configReader, mongoClientWrapper);
  final ActorRef healthCheckingActor =
      initializeHealthCheckActor(configReader, thingsSyncPersistence, policiesSyncPersistence);
  pubSubMediator.tell(new DistributedPubSubMediator.Put(searchActor), getSelf());
  createHealthCheckingActorHttpBinding(configReader.http(), healthCheckingActor, materializer);
  startChildActor(SearchUpdaterRootActor.ACTOR_NAME, SearchUpdaterRootActor.props(configReader, pubSubMediator,
      materializer, thingsSyncPersistence, policiesSyncPersistence));
}
origin: eclipse/ditto

    ThingsPersistenceStreamingActorCreator.props(config, tagsStreamingCacheSize));
pubSubMediator.tell(new DistributedPubSubMediator.Put(getSelf()), getSelf());
pubSubMediator.tell(new DistributedPubSubMediator.Put(persistenceStreamingActor), getSelf());
origin: eclipse/ditto

    ProxyActor.props(pubSubMediator, devOpsCommandsActor, conciergeForwarder));
pubSubMediator.tell(new DistributedPubSubMediator.Put(getSelf()), getSelf());
origin: eclipse/ditto

    PoliciesPersistenceStreamingActorCreator.props(config, tagsStreamingCacheSize));
pubSubMediator.tell(new DistributedPubSubMediator.Put(getSelf()), getSelf());
pubSubMediator.tell(new DistributedPubSubMediator.Put(persistenceStreamingActor), getSelf());
akka.cluster.pubsubDistributedPubSubMediator$Put<init>

Popular methods of DistributedPubSubMediator$Put

    Popular in Java

    • Parsing JSON documents to java classes using gson
    • getContentResolver (Context)
    • setRequestProperty (URLConnection)
      Sets the general request property. If a property with the key already exists, overwrite its value wi
    • scheduleAtFixedRate (ScheduledExecutorService)
      Creates and executes a periodic action that becomes enabled first after the given initial delay, and
    • RandomAccessFile (java.io)
      Allows reading from and writing to a file in a random-access manner. This is different from the uni-
    • Date (java.sql)
      A class which can consume and produce dates in SQL Date format. Dates are represented in SQL as yyyy
    • DecimalFormat (java.text)
      DecimalFormat is a concrete subclass ofNumberFormat that formats decimal numbers. It has a variety o
    • MessageFormat (java.text)
      MessageFormat provides a means to produce concatenated messages in language-neutral way. Use this to
    • SimpleDateFormat (java.text)
      Formats and parses dates in a locale-sensitive manner. Formatting turns a Date into a String, and pa
    • ConcurrentHashMap (java.util.concurrent)
      A hash table supporting full concurrency of retrievals and adjustable expected concurrency for updat
    Codota Logo
    • Products

      Search for Java codeSearch for JavaScript codeEnterprise
    • IDE Plugins

      IntelliJ IDEAWebStormAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimAtomGoLandRubyMineEmacsJupyter
    • Company

      About UsContact UsCareers
    • Resources

      FAQBlogCodota Academy Plugin user guide Terms of usePrivacy policyJava Code IndexJavascript Code Index
    Get Codota for your IDE now